Package | Description |
---|---|
org.apache.hadoop.conf |
Configuration of system parameters.
|
org.apache.hadoop.fs |
Implementations of
AbstractFileSystem for hdfs
over rpc and hdfs over web. |
org.apache.hadoop.fs.permission |
This package provides support for HDFS permission and ACL.
|
org.apache.hadoop.fs.s3a.auth.delegation |
Extensible delegation token support for the S3A connector.
|
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.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 | |
org.apache.hadoop.mapred.lib | |
org.apache.hadoop.mapred.lib.aggregate | |
org.apache.hadoop.mapred.nativetask.serde | |
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.counters |
This package contains the implementations of different types of
map-reduce counters.
|
org.apache.hadoop.mapreduce.lib.aggregate | |
org.apache.hadoop.mapreduce.lib.db | |
org.apache.hadoop.mapreduce.lib.fieldsel | |
org.apache.hadoop.mapreduce.lib.input | |
org.apache.hadoop.mapreduce.lib.join | |
org.apache.hadoop.mapreduce.lib.map | |
org.apache.hadoop.mapreduce.lib.output | |
org.apache.hadoop.mapreduce.lib.output.committer.manifest.files |
Persistence formats.
|
org.apache.hadoop.mapreduce.lib.partition | |
org.apache.hadoop.mapreduce.lib.reduce | |
org.apache.hadoop.mapreduce.security | |
org.apache.hadoop.record |
(DEPRECATED) Hadoop record I/O contains classes and a record description language
translator for simplifying serialization and deserialization of records in a
language-neutral manner.
|
org.apache.hadoop.security | |
org.apache.hadoop.security.authorize |
Support for service-level authorization.
|
org.apache.hadoop.security.token |
Support for delegation tokens.
|
org.apache.hadoop.security.token.delegation |
Router security token delegation.
|
org.apache.hadoop.util |
Common utilities.
|
org.apache.hadoop.util.bloom | |
org.apache.hadoop.yarn.client | |
org.apache.hadoop.yarn.client.api | |
org.apache.hadoop.yarn.conf |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.logaggregation |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.security |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.security.client |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.util |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.util.timeline |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
ByteBufferPool |
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
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.
|
BinaryComparable
Interface supported by
WritableComparable
types supporting ordering/permutation by a representative set of bytes. |
BooleanWritable
A WritableComparable for booleans.
|
ByteBufferPool |
BytesWritable
A byte sequence that is usable as a key or value.
|
ByteWritable
A WritableComparable for a single byte.
|
DoubleWritable
Writable for Double values.
|
FloatWritable
A WritableComparable for floats.
|
IntWritable
A WritableComparable for ints.
|
LongWritable
A WritableComparable for longs.
|
MapFile
A file-based map from keys to values.
|
MapWritable
A Writable Map.
|
MD5Hash
A Writable for MD5 hash values.
|
NullWritable
Singleton Writable with no data.
|
ObjectWritable
A polymorphic Writable that writes an instance with it's class name.
|
RawComparator
A
Comparator that operates directly on byte representations of
objects. |
ShortWritable
A WritableComparable for shorts.
|
SortedMapWritable
A Writable SortedMap.
|
Stringifier
Stringifier interface offers two methods to convert an object
to a string representation and restore the object given its
string representation.
|
Text
This class stores text using standard UTF8 encoding.
|
VIntWritable
A WritableComparable for integer values stored in variable-length format.
|
VLongWritable
A WritableComparable for longs in a variable-length format.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
WritableComparable
A
Writable which is also Comparable . |
WritableComparator
A Comparator for
WritableComparable s. |
WritableFactory
A factory for a class of Writable.
|
Class and Description |
---|
RawComparator
A
Comparator that operates directly on byte representations of
objects. |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Closeable
Deprecated.
use java.io.Closeable
|
RawComparator
A
Comparator that operates directly on byte representations of
objects. |
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Closeable
Deprecated.
use java.io.Closeable
|
LongWritable
A WritableComparable for longs.
|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
Closeable
Deprecated.
use java.io.Closeable
|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
RawComparator
A
Comparator that operates directly on byte representations of
objects. |
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
WritableComparable
A
Writable which is also Comparable . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
WritableComparable
A
Writable which is also Comparable . |
Class and Description |
---|
LongWritable
A WritableComparable for longs.
|
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
BytesWritable
A byte sequence that is usable as a key or value.
|
LongWritable
A WritableComparable for longs.
|
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
WritableComparable
A
Writable which is also Comparable . |
WritableComparator
A Comparator for
WritableComparable s. |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
BytesWritable
A byte sequence that is usable as a key or value.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
WritableComparable
A
Writable which is also Comparable . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
BinaryComparable
Interface supported by
WritableComparable
types supporting ordering/permutation by a representative set of bytes. |
RawComparator
A
Comparator that operates directly on byte representations of
objects. |
WritableComparator
A Comparator for
WritableComparable s. |
Class and Description |
---|
IntWritable
A WritableComparable for ints.
|
LongWritable
A WritableComparable for longs.
|
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
RawComparator
A
Comparator that operates directly on byte representations of
objects. |
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
WritableComparable
A
Writable which is also Comparable . |
WritableComparator
A Comparator for
WritableComparable s. |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Writable
A serializable object which implements a simple, efficient, serialization
protocol, based on
DataInput and DataOutput . |
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Class and Description |
---|
Text
This class stores text using standard UTF8 encoding.
|
Copyright © 2024 Apache Software Foundation. All rights reserved.