Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.hadoop.mapreduce Classes and Interfaces - 162 results found.
NameDescriptionTypePackageFramework
AbstractCountersAn abstract class to provide common implementation for the Counters container in both mapred and mapreduce packages.Classorg.apache.hadoop.mapreduce.countersApache Hadoop
ArrayListBackedIteratorThis class provides an implementation of ResetableIterator.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
BigDecimalSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
BinaryPartitionerPartition BinaryComparable keys using a configurable part of the bytes array returned by BinaryComparable.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
BooleanSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
CancelDelegationTokenRequestInterfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
ChainMapperThe ChainMapper class allows to use multiple Mapper classes within a single The Mapper classes are invoked in a chained (or piped) fashion, the output ofClassorg.apache.hadoop.mapreduce.lib.chainApache Hadoop
ChainReducerThe ChainReducer class allows to chain multiple Mapper classes after a Reducer within the Reducer task.Classorg.apache.hadoop.mapreduce.lib.chainApache Hadoop
CheckpointableContract representing to the framework that the task can be safely preempted and restarted between invocations of the user-defined function.Classorg.apache.hadoop.mapreduce.task.annotationApache Hadoop
CLIClassorg.apache.hadoop.mapreduce.toolsApache Hadoop
ClusterProvides a way to access information about the map/reduce cluster.Classorg.apache.hadoop.mapreduceApache Hadoop
ClusterMetricsStatus information on the current state of the Map-Reduce cluster.Classorg.apache.hadoop.mapreduceApache Hadoop
CombineFileInputFormatAn abstract InputFormat that returns CombineFileSplit's in InputFormat.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineFileRecordReaderA generic RecordReader that can hand out different recordReaders for each chunk in a CombineFileSplit.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineFileRecordReaderWrapperA wrapper class for a record reader that handles a single file split.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineFileSplitA sub-collection of input files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineSequenceFileInputFormatInput format that is a CombineFileInputFormat-equivalent for SequenceFileInputFormat.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineTextInputFormatInput format that is a CombineFileInputFormat-equivalent forSee Also:CombineFileInputFormatClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
ComposableInputFormatRefinement of InputFormat requiring implementors to provide ComposableRecordReader instead of RecordReader.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
ComposableRecordReaderAdditional operations required of a RecordReader to participate in a join.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
CompositeInputFormatAn InputFormat capable of performing joins over a set of data sources sorted and partitioned the same way.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
CompositeInputSplitThis InputSplit contains a set of child InputSplits.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
CompositeRecordReaderA RecordReader that can effect joins of RecordReaders sharing a common key type and partitioning.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
ControlledJobThis class encapsulates a MapReduce job and its dependency.Classorg.apache.hadoop.mapreduce.lib.jobcontrolApache Hadoop
CounterA named counter that tracks the progress of a map/reduce job.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
CounterGroupA group of Counters that logically belong together.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
CounterGroupBaseThe common counter group interface.Interfaceorg.apache.hadoop.mapreduce.countersApache Hadoop
CountersCounters holds per job/task counters, defined either by the Map-Reduce framework or applications.Classorg.apache.hadoop.mapreduceApache Hadoop
DataDrivenDBInputFormatA InputFormat that reads input data from an SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DataDrivenDBRecordReaderA RecordReader that reads records from a SQL table, using data-driven WHERE clause splits.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DateSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBConfigurationA container for configuration property names for jobs with DB input/output.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBInputFormatA InputFormat that reads input data from an SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBOutputFormatA OutputFormat that sends the reduce output to a SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBRecordReaderA RecordReader that reads records from a SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBSplitterDBSplitter will generate DBInputSplits to use with DataDrivenDBInputFormat.Interfaceorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBWritableObjects that are read from/written to a database should implement DBWritable.Interfaceorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DoubleValueSumClassorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
FieldSelectionHelperThis class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.Classorg.apache.hadoop.mapreduce.lib.fieldselApache Hadoop
FieldSelectionMapperThis class implements a mapper class that can be used to perform field selections in a manner similar to unix cut.Classorg.apache.hadoop.mapreduce.lib.fieldselApache Hadoop
FieldSelectionReducerThis class implements a reducer class that can be used to perform field selections in a manner similar to unix cut.Classorg.apache.hadoop.mapreduce.lib.fieldselApache Hadoop
FileInputFormatA base class for file-based InputFormats.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FileInputFormatCounterenum FileInputFormatCounterEnum Constant SummaryClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FileOutputCommitterAn OutputCommitter that commits files specified in job output directory i.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FileOutputFormatA base class for OutputFormats that read from FileSystems.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FileOutputFormatCounterenum FileOutputFormatCounterEnum Constant SummaryClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FileSplitA section of an input file.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FilterOutputFormatFilterOutputFormat is a convenience class that wraps OutputFormat.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FixedLengthInputFormatFixedLengthInputFormat is an input format used to read input files which contain fixed length records.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FloatSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
GetDelegationTokenRequestInterfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
HashPartitionerPartition keys by their Object.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
HistoryFileManagerClassorg.apache.hadoop.mapreduce.v2.hsApache Hadoop
HistoryStorageProvides an API to query jobs that have finished.Interfaceorg.apache.hadoop.mapreduce.v2.hsApache Hadoop
IDA general identifier, which internally stores the id as an integer.Classorg.apache.hadoop.mapreduceApache Hadoop
InnerJoinRecordReaderClassorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
InputFormatInputFormat describes the input-specification for a The Map-Reduce framework relies on the InputFormat of theClassorg.apache.hadoop.mapreduceApache Hadoop
InputSamplerUtility for collecting samples and writing a partition file for TotalOrderPartitioner.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
InputSplitInputSplit represents the data to be processed by an individual Mapper.Classorg.apache.hadoop.mapreduceApache Hadoop
IntegerSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
IntSumReducerClassorg.apache.hadoop.mapreduce.lib.reduceApache Hadoop
InvalidInputExceptionThis class wraps a list of problems with the input, so that the user can get a list of problems together instead of finding and fixing them one Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
InverseMapperA Mapper that swaps keys and values.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
JobThe job submitter's view of the Job.Classorg.apache.hadoop.mapreduceApache Hadoop
JobContextInterfaceorg.apache.hadoop.mapreduceApache Hadoop
JobControlThis class encapsulates a set of MapReduce jobs and its dependency.Classorg.apache.hadoop.mapreduce.lib.jobcontrolApache Hadoop
JobCounterClassorg.apache.hadoop.mapreduceApache Hadoop
JobIDJobID represents the immutable and unique identifier for the job.Classorg.apache.hadoop.mapreduceApache Hadoop
JobPriorityUsed to describe the priority of the running job.Classorg.apache.hadoop.mapreduceApache Hadoop
JobStatusDescribes the current status of a job.Classorg.apache.hadoop.mapreduceApache Hadoop
JoinRecordReaderBase class for Composite joins returning Tuples of arbitrary Writables.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
KeyFieldBasedComparatorThis comparator implementation provides a subset of the features provided by the Unix/GNU Sort.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
KeyFieldBasedPartitionerDefines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
KeyValueLineRecordReaderThis class treats a line in the input as a key/value pair separated by a separator character.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
KeyValueTextInputFormatAn InputFormat for plain text files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
LazyOutputFormatA Convenience class that creates output lazily.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
LongSumReducerClassorg.apache.hadoop.mapreduce.lib.reduceApache Hadoop
LongValueMaxThis class implements a value aggregator that maintain the maximum of a sequence of long values.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
LongValueMinThis class implements a value aggregator that maintain the minimum of a sequence of long values.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
LongValueSumThis class implements a value aggregator that sums up a sequence of long values.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
MapContextThe context that is given to the Mapper.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
MapFileOutputFormatClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
MapperMaps input key/value pairs to a set of intermediate key/value pairs.Classorg.apache.hadoop.mapreduceApache Hadoop
MarkableIteratorMarkableIterator is a wrapper iterator class that implements the MarkableIteratorInterface.Classorg.apache.hadoop.mapreduceApache Hadoop
MultiFilterRecordReaderBase class for Composite join returning values derived from multiple sources, but generally not tuples.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
MultipleInputsThis class supports MapReduce jobs that have multiple input paths with a different InputFormat and Mapper for each pathClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
MultipleOutputsThe MultipleOutputs class simplifies writing output data to multiple outputsClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
MultithreadedMapperMultithreaded implementation for @link org.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
MySQLDataDrivenDBRecordReaderClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
MySQLDBRecordReaderA RecordReader that reads records from a MySQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
NLineInputFormatNLineInputFormat which splits N lines of input as one split.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
NullOutputFormatConsume all outputs and put them in /dev/null.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
OracleDataDrivenDBInputFormatA InputFormat that reads input data from an SQL table in an Oracle db.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OracleDataDrivenDBRecordReaderClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OracleDateSplitter Make use of logic from DateSplitter, since this just needs to use some Oracle-specific functions on the formatting end when generatingClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OracleDBRecordReaderA RecordReader that reads records from an Oracle SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OuterJoinRecordReaderClassorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
OutputCommitterOutputCommitter describes the commit of task output for a The Map-Reduce framework relies on the OutputCommitter of Classorg.apache.hadoop.mapreduceApache Hadoop
OutputFormatOutputFormat describes the output-specification for a The Map-Reduce framework relies on the OutputFormat of theClassorg.apache.hadoop.mapreduceApache Hadoop
OverrideRecordReaderPrefer the "rightmost" data source for this key.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
ParserVery simple shift-reduce parser for join expressions.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
Parser .NodeClassorg.apache.hadoop.mapreduce.lib.join.ParserApache Hadoop
Parser .NodeTokenClassorg.apache.hadoop.mapreduce.lib.join.ParserApache Hadoop
Parser .NumTokenClassorg.apache.hadoop.mapreduce.lib.join.ParserApache Hadoop
Parser .StrTokenClassorg.apache.hadoop.mapreduce.lib.join.ParserApache Hadoop
Parser .TokenTagged-union type for tokens from the join expression.Classorg.apache.hadoop.mapreduce.lib.join.ParserApache Hadoop
Parser .TTypeClassorg.apache.hadoop.mapreduce.lib.join.ParserApache Hadoop
PartialFileOutputCommitterAn OutputCommitter that commits files specified in job output directory i.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
PartialOutputCommitterInterface for an OutputCommitter implementing partial commit of task output, as during preemption.Interfaceorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
PartitionerPartitions the key space.Classorg.apache.hadoop.mapreduceApache Hadoop
QueueAclsInfoClassorg.apache.hadoop.mapreduceApache Hadoop
QueueInfoClass that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.Classorg.apache.hadoop.mapreduceApache Hadoop
QueueStateEnum representing queue stateEnum Constant SummaryClassorg.apache.hadoop.mapreduceApache Hadoop
RecordReaderClassorg.apache.hadoop.mapreduceApache Hadoop
RecordWriterRecordWriter writes the output pairs RecordWriter implementations write the job outputs to theClassorg.apache.hadoop.mapreduceApache Hadoop
ReduceContextThe context passed to the Reducer.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
ReducerReduces a set of intermediate values which share a key to a smaller set of Reducer implementations Classorg.apache.hadoop.mapreduceApache Hadoop
RegexMapperA Mapper that extracts text matching a regular expression.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
RenewDelegationTokenRequestThe request issued by the client to renew a delegation token from the ResourceManager.Interfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
RenewDelegationTokenResponseThe response to a renewDelegationToken call to the ResourceManager.Interfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
ResetableIteratorThis defines an interface to a stateful Iterator that can replay elements added to it directly.Interfaceorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
SequenceFileAsBinaryInputFormatClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileAsBinaryOutputFormatAn OutputFormat that writes keys, values to SequenceFiles in binary(raw) formatClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
SequenceFileAsTextInputFormatThis class is similar to SequenceFileInputFormat, except it generates SequenceFileAsTextRecordReader which converts the input keys and valuesClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileAsTextRecordReaderThis class converts the input keys and values to their String forms by calling toString() method.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileInputFilterA class that allows a map/red job to work on a sample of sequence files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileInputFormatAn InputFormat for SequenceFiles.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileOutputFormatAn OutputFormat that writes SequenceFiles.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
SequenceFileRecordReaderAn RecordReader for SequenceFiles.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
StreamBackedIteratorThis class provides an implementation of ResetableIterator.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
StringValueMaxThis class implements a value aggregator that maintain the biggest of a sequence of strings.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
StringValueMinThis class implements a value aggregator that maintain the smallest of a sequence of strings.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
TaskAttemptContextThe context for task attempts.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
TaskAttemptIDTaskAttemptID represents the immutable and unique identifier for a task attempt.Classorg.apache.hadoop.mapreduceApache Hadoop
TaskCompletionEventClassorg.apache.hadoop.mapreduceApache Hadoop
TaskCompletionEvent .StatusTask Event Attempt failed but there are attempts remaining.Classorg.apache.hadoop.mapreduce.TaskCompletionEventApache Hadoop
TaskCounterClassorg.apache.hadoop.mapreduceApache Hadoop
TaskIDTaskID represents the immutable and unique identifier for a Map or Reduce Task.Classorg.apache.hadoop.mapreduceApache Hadoop
TaskInputOutputContextA context object that allows input and output from the task.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
TaskTrackerInfoInformation about TaskTracker.Classorg.apache.hadoop.mapreduceApache Hadoop
TaskTypeEnum for map, reduce, job-setup, job-cleanup, task-cleanup task types.Classorg.apache.hadoop.mapreduceApache Hadoop
TextInputFormatAn InputFormat for plain text files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
TextOutputFormatAn OutputFormat that writes plain text files.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
TextSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
TokenCacheThis class provides user facing APIs for transferring secrets from the job client to the tasks.Classorg.apache.hadoop.mapreduce.securityApache Hadoop
TokenCounterMapperTokenize the input values and emit each word with a count of 1.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
TotalOrderPartitionerPartitioner effecting a total order by reading split points from an externally generated source.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
TupleWritableWritable type storing multiple Writables.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
UniqValueCountThis class implements a value aggregator that dedupes a sequence of objects.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
UserDefinedValueAggregatorDescriptorThis class implements a wrapper for a user defined value aggregator descriptor.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorThis interface defines the minimal protocol for value aggregators.Interfaceorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorBaseDescriptorThis class implements the common functionalities of the subclasses of ValueAggregatorDescriptor class.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorCombinerThis class implements the generic combiner of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorDescriptorThis interface defines the contract a value aggregator descriptor must support.Interfaceorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorJobThis is the main class for creating a map/reduce job using Aggregate framework.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorJobBaseThis abstract class implements some common functionalities of the the generic mapper, reducer and combiner classes of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorMapperThis class implements the generic mapper of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorReducerThis class implements the generic reducer of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueHistogramThis class implements a value aggregator that computes the histogram of a sequence of strings.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
WrappedMapperA Mapper which wraps a given one to allow custom Mapper.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
WrappedRecordReaderProxy class for a RecordReader participating in the join framework.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
WrappedReducerA Reducer which wraps a given one to allow for custom Reducer.Classorg.apache.hadoop.mapreduce.lib.reduceApache Hadoop