| Modifier and Type | Class and Description | 
|---|---|
| class  | ConfigurationProvides access to configuration parameters. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ContentSummaryStore the summary of a content (a directory or a file). | 
| class  | FileChecksumAn abstract class representing file checksums for files. | 
| class  | FileStatusInterface that represents the client side information for a file. | 
| class  | FsServerDefaultsProvides server default configuration values to clients. | 
| class  | FsStatusThis class is used to represent the capacity, free and used space on a
  FileSystem. | 
| class  | LocatedFileStatusThis class defines a FileStatus that includes a file's block locations. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FsCreateModesA class that stores both masked and unmasked create modes
 and is a drop-in replacement for masked permission. | 
| class  | FsPermissionA class for file/directory permissions. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | WritableComparable<T>A  Writablewhich is alsoComparable. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractMapWritableAbstract 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  | ArrayPrimitiveWritableThis is a wrapper class. | 
| class  | ArrayWritableA Writable for arrays containing instances of a class. | 
| class  | BooleanWritableA WritableComparable for booleans. | 
| class  | BytesWritableA byte sequence that is usable as a key or value. | 
| class  | ByteWritableA WritableComparable for a single byte. | 
| class  | CompressedWritableA base-class for Writables which store themselves compressed and lazily
 inflate on field access. | 
| class  | DoubleWritableWritable for Double values. | 
| class  | EnumSetWritable<E extends Enum<E>>A Writable wrapper for EnumSet. | 
| class  | FloatWritableA WritableComparable for floats. | 
| class  | GenericWritableA wrapper for Writable instances. | 
| class  | IntWritableA WritableComparable for ints. | 
| class  | LongWritableA WritableComparable for longs. | 
| class  | MapWritableA Writable Map. | 
| class  | MD5HashA Writable for MD5 hash values. | 
| class  | NullWritableSingleton Writable with no data. | 
| class  | ObjectWritableA polymorphic Writable that writes an instance with it's class name. | 
| class  | ShortWritableA WritableComparable for shorts. | 
| class  | SortedMapWritable<K extends WritableComparable<? super K>>A Writable SortedMap. | 
| class  | TextThis class stores text using standard UTF8 encoding. | 
| class  | TwoDArrayWritableA Writable for 2D arrays containing a matrix of instances of a class. | 
| class  | VersionedWritableA base class for Writables that provides version checking. | 
| class  | VIntWritableA WritableComparable for integer values stored in variable-length format. | 
| class  | VLongWritableA 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 | GenericWritable. get()Return the wrapped instance. | 
| Writable[] | ArrayWritable. get() | 
| Writable[][] | TwoDArrayWritable. get() | 
| Writable | MapWritable. get(Object key) | 
| Writable | SortedMapWritable. get(Object key) | 
| 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 | SortedMapWritable. put(K key,
   Writable value) | 
| Writable | MapWritable. put(Writable key,
   Writable value) | 
| Writable | MapWritable. remove(Object key) | 
| Writable | SortedMapWritable. remove(Object key) | 
| Modifier and Type | Method and Description | 
|---|---|
| Set<Map.Entry<Writable,Writable>> | MapWritable. entrySet() | 
| Set<Map.Entry<Writable,Writable>> | MapWritable. entrySet() | 
| Set<Map.Entry<K,Writable>> | SortedMapWritable. entrySet() | 
| Class<? extends Writable> | ArrayWritable. getValueClass() | 
| SortedMap<K,Writable> | SortedMapWritable. headMap(K toKey) | 
| Set<Writable> | MapWritable. keySet() | 
| SortedMap<K,Writable> | SortedMapWritable. subMap(K fromKey,
      K toKey) | 
| SortedMap<K,Writable> | SortedMapWritable. tailMap(K fromKey) | 
| Collection<Writable> | MapWritable. values() | 
| Collection<Writable> | SortedMapWritable. values() | 
| Modifier and Type | Method and Description | 
|---|---|
| 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 | SortedMapWritable. put(K 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 | SortedMapWritable. putAll(Map<? extends K,? extends Writable> t) | 
| void | MapWritable. putAll(Map<? extends Writable,? extends Writable> t) | 
| void | MapWritable. putAll(Map<? extends Writable,? extends Writable> t) | 
| Constructor and Description | 
|---|
| ArrayWritable(Class<? extends Writable> valueClass,
             Writable[] values) | 
| TwoDArrayWritable(Class valueClass,
                 Writable[][] values) | 
| Constructor and Description | 
|---|
| ArrayWritable(Class<? extends Writable> valueClass) | 
| ArrayWritable(Class<? extends Writable> valueClass,
             Writable[] values) | 
| Modifier and Type | Method and Description | 
|---|---|
| static <T extends Writable> | Client. getAsyncRpcResponse() | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract Writable | Server. call(org.apache.hadoop.ipc.RPC.RpcKind rpcKind,
    String protocol,
    Writable param,
    long receiveTime)Called for each call. | 
| Writable | Client. call(org.apache.hadoop.ipc.RPC.RpcKind rpcKind,
    Writable rpcRequest,
    org.apache.hadoop.ipc.Client.ConnectionId remoteId,
    AtomicBoolean fallbackToSimpleAuth)Make a call, passing  rpcRequest, to the IPC server defined byremoteId, returning the rpc respond. | 
| Writable | Client. call(org.apache.hadoop.ipc.RPC.RpcKind rpcKind,
    Writable rpcRequest,
    org.apache.hadoop.ipc.Client.ConnectionId remoteId,
    AtomicBoolean fallbackToSimpleAuth,
    org.apache.hadoop.ipc.AlignmentContext alignmentContext) | 
| 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(org.apache.hadoop.ipc.protobuf.RpcHeaderProtos.RpcKindProto rpcKind) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract Writable | Server. call(org.apache.hadoop.ipc.RPC.RpcKind rpcKind,
    String protocol,
    Writable param,
    long receiveTime)Called for each call. | 
| Writable | Client. call(org.apache.hadoop.ipc.RPC.RpcKind rpcKind,
    Writable rpcRequest,
    org.apache.hadoop.ipc.Client.ConnectionId remoteId,
    AtomicBoolean fallbackToSimpleAuth)Make a call, passing  rpcRequest, to the IPC server defined byremoteId, returning the rpc respond. | 
| Writable | Client. call(org.apache.hadoop.ipc.RPC.RpcKind rpcKind,
    Writable rpcRequest,
    org.apache.hadoop.ipc.Client.ConnectionId remoteId,
    AtomicBoolean fallbackToSimpleAuth,
    org.apache.hadoop.ipc.AlignmentContext alignmentContext) | 
| 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(org.apache.hadoop.ipc.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  Writableclass. | 
| 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 | Interface and Description | 
|---|---|
| interface  | InputSplitInputSplitrepresents the data to be processed by an 
 individualMapper. | 
| interface  | InputSplitWithLocationInfo | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClusterStatusStatus information on the current state of the Map-Reduce cluster. | 
| static class  | Counters.CounterA counter record, comprising its name and value. | 
| static class  | Counters.GroupGroupof counters, comprising of counters from a particular
  counterEnumclass. | 
| class  | JobConfA map/reduce job configuration. | 
| class  | JobQueueInfoClass that contains the information regarding the Job Queues which are 
 maintained by the Hadoop Map/Reduce framework. | 
| class  | MultiFileSplitA sub-collection of input files. | 
| Modifier and Type | Method and Description | 
|---|---|
| static <K extends WritableComparable,V extends Writable> | MapFileOutputFormat. getEntry(org.apache.hadoop.io.MapFile.Reader[] readers,
        Partitioner<K,V> partitioner,
        K key,
        V value)Get an entry from output generated by this class. | 
| Modifier and Type | Method and Description | 
|---|---|
| static <K extends WritableComparable,V extends Writable> | MapFileOutputFormat. getEntry(org.apache.hadoop.io.MapFile.Reader[] readers,
        Partitioner<K,V> partitioner,
        K key,
        V value)Get an entry from output generated by this class. | 
| Modifier and Type | Method and Description | 
|---|---|
| RecordWriter<WritableComparable,Writable> | MapFileOutputFormat. getRecordWriter(FileSystem ignored,
               JobConf job,
               String name,
               Progressable progress) | 
| static Class<? extends Writable> | SequenceFileAsBinaryOutputFormat. getSequenceFileOutputValueClass(JobConf conf)Get the value class for the  SequenceFile | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ArrayListBackedIterator<X extends Writable>This class provides an implementation of ResetableIterator. | 
| interface  | ComposableInputFormat<K extends WritableComparable,V extends Writable>Refinement of InputFormat requiring implementors to provide
 ComposableRecordReader instead of RecordReader. | 
| interface  | ComposableRecordReader<K extends WritableComparable,V extends Writable>Additional operations required of a RecordReader to participate in a join. | 
| 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  | 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  | MultiFilterRecordReader<K extends WritableComparable,V extends Writable>Base class for Composite join returning values derived from multiple
 sources, but generally not tuples. | 
| class  | OverrideRecordReader<K extends WritableComparable,V extends Writable>Prefer the "rightmost" data source for this key. | 
| interface  | ResetableIterator<T extends Writable>This defines an interface to a stateful Iterator that can replay elements
 added to it directly. | 
| class  | StreamBackedIterator<X extends Writable>This class provides an implementation of ResetableIterator. | 
| class  | WrappedRecordReader<K extends WritableComparable,U extends Writable>Proxy class for a RecordReader participating in the join framework. | 
| Constructor and Description | 
|---|
| TupleWritable(Writable[] vals)Initialize tuple with storage; unknown whether any of them contain
 "written" values. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ValueAggregatorCombiner<K1 extends WritableComparable,V1 extends Writable>This class implements the generic combiner of Aggregate. | 
| class  | ValueAggregatorJobBase<K1 extends WritableComparable,V1 extends Writable>This abstract class implements some common functionalities of the
 the generic mapper, reducer and combiner classes of Aggregate. | 
| class  | ValueAggregatorMapper<K1 extends WritableComparable,V1 extends Writable>This class implements the generic mapper of Aggregate. | 
| class  | ValueAggregatorReducer<K1 extends WritableComparable,V1 extends Writable>This class implements the generic reducer of Aggregate. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DefaultSerializer. deserialize(DataInput in,
           int length,
           Writable w) | 
| int | DefaultSerializer. getLength(Writable w) | 
| void | DefaultSerializer. serialize(Writable w,
         DataOutput out) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | CounterA named counter that tracks the progress of a map/reduce job. | 
| interface  | CounterGroupA group of  Counters that logically belong together. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClusterMetricsStatus information on the current state of the Map-Reduce cluster. | 
| class  | CountersCountersholds per job/task counters, defined either by the
 Map-Reduce framework or applications. | 
| class  | IDA general identifier, which internally stores the id
 as an integer. | 
| class  | JobIDJobID represents the immutable and unique identifier for 
 the job. | 
| class  | JobStatusDescribes the current status of a job. | 
| class  | QueueAclsInfoClass to encapsulate Queue ACLs for a particular
  user. | 
| class  | QueueInfoClass that contains the information regarding the Job Queues which are 
 maintained by the Hadoop Map/Reduce framework. | 
| class  | TaskAttemptIDTaskAttemptID represents the immutable and unique identifier for 
 a task attempt. | 
| class  | TaskCompletionEventThis is used to track task completion events on 
 job tracker. | 
| class  | TaskIDTaskID represents the immutable and unique identifier for 
 a Map or Reduce Task. | 
| class  | org.apache.hadoop.mapreduce.TaskReportA report on the state of a task. | 
| class  | TaskTrackerInfoInformation about TaskTracker. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | CounterGroupBase<T extends Counter>The common counter group interface. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCounters<C extends Counter,G extends CounterGroupBase<C>>An abstract class to provide common implementation for the Counters
 container in both mapred and mapreduce packages. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ValueAggregatorCombiner<K1 extends WritableComparable<?>,V1 extends Writable>This class implements the generic combiner of Aggregate. | 
| class  | ValueAggregatorJobBase<K1 extends WritableComparable<?>,V1 extends Writable>This abstract class implements some common functionalities of the
 the generic mapper, reducer and combiner classes of Aggregate. | 
| class  | ValueAggregatorMapper<K1 extends WritableComparable<?>,V1 extends Writable>This class implements the generic mapper of Aggregate. | 
| class  | ValueAggregatorReducer<K1 extends WritableComparable<?>,V1 extends Writable>This class implements the generic reducer of Aggregate. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CombineFileSplitA sub-collection of input files. | 
| class  | FileSplitA section of an input file. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ArrayListBackedIterator<X extends Writable>This class provides an implementation of ResetableIterator. | 
| class  | ComposableInputFormat<K extends WritableComparable<?>,V extends Writable>Refinement of InputFormat requiring implementors to provide
 ComposableRecordReader instead of RecordReader. | 
| class  | ComposableRecordReader<K extends WritableComparable<?>,V extends Writable>Additional operations required of a RecordReader to participate in a join. | 
| 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  | 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  | MultiFilterRecordReader<K extends WritableComparable<?>,V extends Writable>Base class for Composite join returning values derived from multiple
 sources, but generally not tuples. | 
| class  | OverrideRecordReader<K extends WritableComparable<?>,V extends Writable>Prefer the "rightmost" data source for this key. | 
| interface  | ResetableIterator<T extends Writable>This defines an interface to a stateful Iterator that can replay elements
 added to it directly. | 
| class  | StreamBackedIterator<X extends Writable>This class provides an implementation of ResetableIterator. | 
| class  | WrappedRecordReader<K extends WritableComparable<?>,U extends Writable>Proxy class for a RecordReader participating in the join framework. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CompositeInputSplitThis InputSplit contains a set of child InputSplits. | 
| class  | TupleWritableWritable type storing multiple  Writables. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected X | CompositeRecordReader. value | 
| Modifier and Type | Method and Description | 
|---|---|
| Writable | TupleWritable. get(int i)Get ith Writable from Tuple. | 
| Modifier and Type | Method and Description | 
|---|---|
| Iterator<Writable> | TupleWritable. iterator()Return an iterator over the elements in this tuple. | 
| Constructor and Description | 
|---|
| TupleWritable(Writable[] vals)Initialize tuple with storage; unknown whether any of them contain
 "written" values. | 
| Modifier and Type | Method and Description | 
|---|---|
| static <K extends WritableComparable<?>,V extends Writable> | MapFileOutputFormat. getEntry(org.apache.hadoop.io.MapFile.Reader[] readers,
        Partitioner<K,V> partitioner,
        K key,
        V value)Get an entry from output generated by this class. | 
| Modifier and Type | Method and Description | 
|---|---|
| static <K extends WritableComparable<?>,V extends Writable> | MapFileOutputFormat. getEntry(org.apache.hadoop.io.MapFile.Reader[] readers,
        Partitioner<K,V> partitioner,
        K key,
        V value)Get an entry from output generated by this class. | 
| Modifier and Type | Method and Description | 
|---|---|
| RecordWriter<WritableComparable<?>,Writable> | MapFileOutputFormat. getRecordWriter(TaskAttemptContext context) | 
| static Class<? extends Writable> | SequenceFileAsBinaryOutputFormat. getSequenceFileOutputValueClass(JobContext job)Get the value class for the  SequenceFile | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RecordDeprecated. 
 Replaced by Avro. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CredentialsA class that provides the facilities of reading and writing
 secret keys and Tokens. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AccessControlListClass 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  | TokenIdentifierAn 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 | Method and Description | 
|---|---|
| static void | ReflectionUtils. cloneWritableInto(Writable dst,
                 Writable src)Deprecated.  | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BloomFilterImplements a Bloom filter, as defined by Bloom in 1970. | 
| class  | CountingBloomFilterImplements a counting Bloom filter, as defined by Fan et al. | 
| class  | DynamicBloomFilterImplements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper. | 
| class  | org.apache.hadoop.util.bloom.FilterDefines the general behavior of a filter. | 
| class  | RetouchedBloomFilterImplements a retouched Bloom filter, as defined in the CoNEXT 2006 paper. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | YarnConfiguration | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | AggregatedLogFormat.LogKey | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AMRMTokenIdentifierAMRMTokenIdentifier is the TokenIdentifier to be used by
 ApplicationMasters to authenticate to the ResourceManager. | 
| class  | ContainerTokenIdentifierTokenIdentifier for a container. | 
| class  | NMTokenIdentifier | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientToAMTokenIdentifier | 
| class  | RMDelegationTokenIdentifierDelegation Token Identifier that identifies the delegation tokens from the 
 Resource Manager. | 
| class  | TimelineDelegationTokenIdentifier | 
| class  | org.apache.hadoop.yarn.security.client.YARNDelegationTokenIdentifier | 
Copyright © 2020 Apache Software Foundation. All rights reserved.