Package | Description |
---|---|
org.apache.hadoop.conf |
Configuration of system parameters.
|
org.apache.hadoop.crypto.key.kms | |
org.apache.hadoop.fs |
An abstract file system API.
|
org.apache.hadoop.fs.permission | |
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.ipc |
Tools to help define network clients and servers.
|
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.record.meta | |
org.apache.hadoop.security | |
org.apache.hadoop.security.authorize | |
org.apache.hadoop.security.token | |
org.apache.hadoop.security.token.delegation | |
org.apache.hadoop.security.token.delegation.web | |
org.apache.hadoop.util |
Common utilities.
|
org.apache.hadoop.util.bloom |
Modifier and Type | Class and Description |
---|---|
class |
Configuration
Provides access to configuration parameters.
|
Modifier and Type | Class and Description |
---|---|
static class |
KMSDelegationToken.KMSDelegationTokenIdentifier
DelegationTokenIdentifier used for the KMS.
|
Modifier and Type | Class and Description |
---|---|
class |
ContentSummary
Store the summary of a content (a directory or a file).
|
class |
FileChecksum
An abstract class representing file checksums for files.
|
class |
FileStatus
Interface that represents the client side information for a file.
|
class |
FsServerDefaults
Provides server default configuration values to clients.
|
class |
FsStatus
This class is used to represent the capacity, free and used space on a
FileSystem . |
class |
LocatedFileStatus
This class defines a FileStatus that includes a file's block locations.
|
class |
MD5MD5CRC32CastagnoliFileChecksum
For CRC32 with the Castagnoli polynomial
|
class |
org.apache.hadoop.fs.MD5MD5CRC32FileChecksum
MD5 of MD5 of CRC32.
|
class |
MD5MD5CRC32GzipFileChecksum
For CRC32 with the Gzip polynomial
|
Modifier and Type | Class and Description |
---|---|
class |
FsPermission
A class for file/directory permissions.
|
Modifier and Type | Interface and Description |
---|---|
interface |
WritableComparable<T>
A
Writable which is also Comparable . |
Modifier and Type | Class and Description |
---|---|
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 |
ArrayPrimitiveWritable
This is a wrapper class.
|
class |
ArrayWritable
A Writable for arrays containing instances of a class.
|
class |
BooleanWritable
A WritableComparable for booleans.
|
class |
BytesWritable
A byte sequence that is usable as a key or value.
|
class |
ByteWritable
A WritableComparable for a single byte.
|
class |
CompressedWritable
A base-class for Writables which store themselves compressed and lazily
inflate on field access.
|
class |
DoubleWritable
Writable for Double values.
|
class |
EnumSetWritable<E extends Enum<E>>
A Writable wrapper for EnumSet.
|
class |
FloatWritable
A WritableComparable for floats.
|
class |
GenericWritable
A wrapper for Writable instances.
|
class |
IntWritable
A WritableComparable for ints.
|
class |
LongWritable
A WritableComparable for longs.
|
class |
MapWritable
A Writable Map.
|
class |
MD5Hash
A Writable for MD5 hash values.
|
class |
NullWritable
Singleton Writable with no data.
|
class |
ObjectWritable
A polymorphic Writable that writes an instance with it's class name.
|
static class |
SequenceFile.Metadata
The class encapsulating with the metadata of a file.
|
class |
ShortWritable
A WritableComparable for shorts.
|
class |
SortedMapWritable
A Writable SortedMap.
|
class |
Text
This class stores text using standard UTF8 encoding.
|
class |
TwoDArrayWritable
A Writable for 2D arrays containing a matrix of instances of a class.
|
class |
VersionedWritable
A base class for Writables that provides version checking.
|
class |
VIntWritable
A WritableComparable for integer values stored in variable-length format.
|
class |
VLongWritable
A WritableComparable for longs in a variable-length format.
|
Modifier and Type | Method and Description |
---|---|
static <T extends Writable> |
WritableUtils.clone(T orig,
Configuration conf)
Make a copy of a writable object using serialization to a buffer.
|
Modifier and Type | Method and Description |
---|---|
Writable[][] |
TwoDArrayWritable.get() |
Writable |
GenericWritable.get()
Return the wrapped instance.
|
Writable[] |
ArrayWritable.get() |
Writable |
ArrayFile.Reader.get(long n,
Writable value)
Return the
n th value in the file. |
Writable |
SortedMapWritable.get(Object key) |
Writable |
MapWritable.get(Object key) |
Writable |
MapFile.Reader.get(WritableComparable key,
Writable val)
Return the value for the named key, or null if none exists.
|
Writable |
BloomMapFile.Reader.get(WritableComparable key,
Writable val)
Fast version of the
MapFile.Reader.get(WritableComparable, Writable) method. |
Writable |
WritableFactory.newInstance()
Return a new instance.
|
static Writable |
WritableFactories.newInstance(Class<? extends Writable> c)
Create a new instance of a class with a defined factory.
|
static Writable |
WritableFactories.newInstance(Class<? extends Writable> c,
Configuration conf)
Create a new instance of a class with a defined factory.
|
Writable |
ArrayFile.Reader.next(Writable value)
Read and return the next value in the file.
|
Writable |
SortedMapWritable.put(WritableComparable key,
Writable value) |
Writable |
MapWritable.put(Writable key,
Writable value) |
Writable |
SortedMapWritable.remove(Object key) |
Writable |
MapWritable.remove(Object key) |
Modifier and Type | Method and Description |
---|---|
Set<Map.Entry<WritableComparable,Writable>> |
SortedMapWritable.entrySet() |
Set<Map.Entry<Writable,Writable>> |
MapWritable.entrySet() |
Set<Map.Entry<Writable,Writable>> |
MapWritable.entrySet() |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.headMap(WritableComparable toKey) |
Set<Writable> |
MapWritable.keySet() |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.subMap(WritableComparable fromKey,
WritableComparable toKey) |
SortedMap<WritableComparable,Writable> |
SortedMapWritable.tailMap(WritableComparable fromKey) |
Collection<Writable> |
SortedMapWritable.values() |
Collection<Writable> |
MapWritable.values() |
Modifier and Type | Method and Description |
---|---|
void |
ArrayFile.Writer.append(Writable value)
Append a value to the file.
|
void |
MapFile.Writer.append(WritableComparable key,
Writable val)
Append a key/value pair to the map.
|
void |
BloomMapFile.Writer.append(WritableComparable key,
Writable val) |
void |
SequenceFile.Writer.append(Writable key,
Writable val)
Append a key/value pair.
|
static void |
WritableUtils.cloneInto(Writable dst,
Writable src)
Deprecated.
use ReflectionUtils.cloneInto instead.
|
protected void |
AbstractMapWritable.copy(Writable other)
Used by child copy constructors.
|
Writable |
ArrayFile.Reader.get(long n,
Writable value)
Return the
n th value in the file. |
Writable |
MapFile.Reader.get(WritableComparable key,
Writable val)
Return the value for the named key, or null if none exists.
|
Writable |
BloomMapFile.Reader.get(WritableComparable key,
Writable val)
Fast version of the
MapFile.Reader.get(WritableComparable, Writable) method. |
WritableComparable |
MapFile.Reader.getClosest(WritableComparable key,
Writable val)
Finds the record that is the closest match to the specified key.
|
WritableComparable |
MapFile.Reader.getClosest(WritableComparable key,
Writable val,
boolean before)
Finds the record that is the closest match to the specified key.
|
void |
SequenceFile.Reader.getCurrentValue(Writable val)
Get the 'value' corresponding to the last read 'key'.
|
boolean |
SequenceFile.Reader.next(Writable key)
Read the next key in the file into
key , skipping its
value. |
Writable |
ArrayFile.Reader.next(Writable value)
Read and return the next value in the file.
|
boolean |
MapFile.Reader.next(WritableComparable key,
Writable val)
Read the next key/value pair in the map into
key and
val . |
boolean |
SequenceFile.Reader.next(Writable key,
Writable val)
Read the next key/value pair in the file into
key and
val . |
Writable |
SortedMapWritable.put(WritableComparable key,
Writable value) |
Writable |
MapWritable.put(Writable key,
Writable value) |
void |
GenericWritable.set(Writable obj)
Set the instance that is wrapped.
|
void |
ArrayWritable.set(Writable[] values) |
void |
TwoDArrayWritable.set(Writable[][] values) |
static byte[] |
WritableUtils.toByteArray(Writable... writables)
Convert writables to a byte array
|
Modifier and Type | Method and Description |
---|---|
static long |
MapFile.fix(FileSystem fs,
Path dir,
Class<? extends Writable> keyClass,
Class<? extends Writable> valueClass,
boolean dryrun,
Configuration conf)
This method attempts to fix a corrupt MapFile by re-creating its index.
|
static long |
MapFile.fix(FileSystem fs,
Path dir,
Class<? extends Writable> keyClass,
Class<? extends Writable> valueClass,
boolean dryrun,
Configuration conf)
This method attempts to fix a corrupt MapFile by re-creating its index.
|
static Writable |
WritableFactories.newInstance(Class<? extends Writable> c)
Create a new instance of a class with a defined factory.
|
static Writable |
WritableFactories.newInstance(Class<? extends Writable> c,
Configuration conf)
Create a new instance of a class with a defined factory.
|
void |
MapWritable.putAll(Map<? extends Writable,? extends Writable> t) |
void |
MapWritable.putAll(Map<? extends Writable,? extends Writable> t) |
void |
SortedMapWritable.putAll(Map<? extends WritableComparable,? extends Writable> t) |
Constructor and Description |
---|
ArrayWritable(Class<? extends Writable> valueClass,
Writable[] values) |
TwoDArrayWritable(Class valueClass,
Writable[][] values) |
Constructor and Description |
---|
ArrayFile.Writer(Configuration conf,
FileSystem fs,
String file,
Class<? extends Writable> valClass)
Create the named file for values of the named class.
|
ArrayFile.Writer(Configuration conf,
FileSystem fs,
String file,
Class<? extends Writable> valClass,
SequenceFile.CompressionType compress,
Progressable progress)
Create the named file for values of the named class.
|
ArrayWritable(Class<? extends Writable> valueClass) |
ArrayWritable(Class<? extends Writable> valueClass,
Writable[] values) |
BloomMapFile.Writer(Configuration conf,
FileSystem fs,
String dirName,
Class<? extends WritableComparable> keyClass,
Class<? extends Writable> valClass,
SequenceFile.CompressionType compress,
CompressionCodec codec,
Progressable progress)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
ProtocolSignature |
class |
org.apache.hadoop.ipc.RpcWritable |
static class |
RpcWritable.Buffer
adapter to allow decoding of writables and protobufs from a byte buffer.
|
Modifier and Type | Method and Description |
---|---|
static <T extends Writable> |
Client.getAsyncRpcResponse() |
Modifier and Type | Method and Description |
---|---|
abstract Writable |
Server.call(RPC.RpcKind rpcKind,
String protocol,
Writable param,
long receiveTime)
Called for each call.
|
Writable |
RPC.Server.call(RPC.RpcKind rpcKind,
String protocol,
Writable rpcRequest,
long receiveTime) |
Writable |
Client.call(RPC.RpcKind rpcKind,
Writable rpcRequest,
org.apache.hadoop.ipc.Client.ConnectionId remoteId,
AtomicBoolean fallbackToSimpleAuth)
Make a call, passing
rpcRequest , to the IPC server defined by
remoteId , returning the rpc respond. |
Writable |
Server.call(Writable param,
long receiveTime)
Deprecated.
Use
Server.call(RPC.RpcKind, String, Writable, long)
instead. |
Modifier and Type | Method and Description |
---|---|
Class<? extends Writable> |
Server.getRpcRequestWrapper(RpcHeaderProtos.RpcKindProto rpcKind) |
Modifier and Type | Method and Description |
---|---|
abstract Writable |
Server.call(RPC.RpcKind rpcKind,
String protocol,
Writable param,
long receiveTime)
Called for each call.
|
Writable |
RPC.Server.call(RPC.RpcKind rpcKind,
String protocol,
Writable rpcRequest,
long receiveTime) |
Writable |
Client.call(RPC.RpcKind rpcKind,
Writable rpcRequest,
org.apache.hadoop.ipc.Client.ConnectionId remoteId,
AtomicBoolean fallbackToSimpleAuth)
Make a call, passing
rpcRequest , to the IPC server defined by
remoteId , returning the rpc respond. |
Writable |
Server.call(Writable param,
long receiveTime)
Deprecated.
Use
Server.call(RPC.RpcKind, String, Writable, long)
instead. |
Modifier and Type | Method and Description |
---|---|
static void |
Server.registerProtocolEngine(RPC.RpcKind rpcKind,
Class<? extends Writable> rpcRequestWrapperClass,
org.apache.hadoop.ipc.RPC.RpcInvoker rpcInvoker)
Register a RPC kind and the class to deserialize the rpc request.
|
Constructor and Description |
---|
Client(Class<? extends Writable> valueClass,
Configuration conf)
Construct an IPC client with the default SocketFactory
|
Client(Class<? extends Writable> valueClass,
Configuration conf,
SocketFactory factory)
Construct an IPC client whose values are of the given
Writable
class. |
RPC.Server(String bindAddress,
int port,
Class<? extends Writable> paramClass,
int handlerCount,
int numReaders,
int queueSizePerHandler,
Configuration conf,
String serverName,
SecretManager<? extends TokenIdentifier> secretManager,
String portRangeConfig) |
Server(String bindAddress,
int port,
Class<? extends Writable> paramClass,
int handlerCount,
Configuration conf) |
Server(String bindAddress,
int port,
Class<? extends Writable> rpcRequestClass,
int handlerCount,
int numReaders,
int queueSizePerHandler,
Configuration conf,
String serverName,
SecretManager<? extends TokenIdentifier> secretManager) |
Server(String bindAddress,
int port,
Class<? extends Writable> rpcRequestClass,
int handlerCount,
int numReaders,
int queueSizePerHandler,
Configuration conf,
String serverName,
SecretManager<? extends TokenIdentifier> secretManager,
String portRangeConfig)
Constructs a server listening on the named port and address.
|
Modifier and Type | Class and Description |
---|---|
class |
Record
Deprecated.
Replaced by Avro.
|
Modifier and Type | Class and Description |
---|---|
class |
RecordTypeInfo
Deprecated.
Replaced by Avro.
|
Modifier and Type | Class and Description |
---|---|
class |
Credentials
A class that provides the facilities of reading and writing
secret keys and Tokens.
|
Modifier and Type | Class and Description |
---|---|
class |
AccessControlList
Class representing a configured access control list.
|
Modifier and Type | Class and Description |
---|---|
class |
Token<T extends TokenIdentifier>
The client-side form of the token.
|
class |
TokenIdentifier
An identifier that identifies a token, may contain public information
about a token, including its kind (or type).
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDelegationTokenIdentifier |
Modifier and Type | Class and Description |
---|---|
class |
org.apache.hadoop.security.token.delegation.web.DelegationTokenIdentifier
Concrete delegation token identifier used by
DelegationTokenManager ,
KerberosDelegationTokenAuthenticationHandler and
DelegationTokenAuthenticationFilter . |
Modifier and Type | Method and Description |
---|---|
static void |
ReflectionUtils.cloneWritableInto(Writable dst,
Writable src)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
BloomFilter
Implements a Bloom filter, as defined by Bloom in 1970.
|
class |
CountingBloomFilter
Implements a counting Bloom filter, as defined by Fan et al.
|
class |
DynamicBloomFilter
Implements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper.
|
class |
org.apache.hadoop.util.bloom.Filter
Defines the general behavior of a filter.
|
class |
RetouchedBloomFilter
Implements a retouched Bloom filter, as defined in the CoNEXT 2006 paper.
|
Copyright © 2017 Apache Software Foundation. All Rights Reserved.