Uses of Interface
org.apache.hadoop.io.Writable

Packages that use Writable
org.apache.hadoop.conf Configuration of system parameters. 
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.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.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.util Common utilities. 
org.apache.hadoop.util.bloom   
 

Uses of Writable in org.apache.hadoop.conf
 

Classes in org.apache.hadoop.conf that implement Writable
 class Configuration
          Provides access to configuration parameters.
 

Uses of Writable in org.apache.hadoop.fs
 

Classes in org.apache.hadoop.fs that implement Writable
 class BlockLocation
           
 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
 

Uses of Writable in org.apache.hadoop.fs.permission
 

Classes in org.apache.hadoop.fs.permission that implement Writable
 class FsPermission
          A class for file/directory permissions.
 

Uses of Writable in org.apache.hadoop.io
 

Subinterfaces of Writable in org.apache.hadoop.io
 interface WritableComparable<T>
          A Writable which is also Comparable.
 

Classes in org.apache.hadoop.io that implement Writable
 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.
 

Methods in org.apache.hadoop.io with type parameters of type Writable
static
<T extends Writable>
T
WritableUtils.clone(T orig, Configuration conf)
          Make a copy of a writable object using serialization to a buffer.
 

Methods in org.apache.hadoop.io that return Writable
 Writable[][] TwoDArrayWritable.get()
           
 Writable[] ArrayWritable.get()
           
 Writable GenericWritable.get()
          Return the wrapped instance.
 Writable ArrayFile.Reader.get(long n, Writable value)
          Return the nth 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)
          
 

Methods in org.apache.hadoop.io that return types with arguments of type Writable
 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()
          
 

Methods in org.apache.hadoop.io with parameters of type Writable
 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 nth 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
 

Method parameters in org.apache.hadoop.io with type arguments of type Writable
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)
          
 

Constructors in org.apache.hadoop.io with parameters of type Writable
ArrayWritable(Class<? extends Writable> valueClass, Writable[] values)
           
TwoDArrayWritable(Class valueClass, Writable[][] values)
           
 

Constructor parameters in org.apache.hadoop.io with type arguments of type Writable
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. 
 

Uses of Writable in org.apache.hadoop.io.serializer
 

Methods in org.apache.hadoop.io.serializer that return types with arguments of type Writable
 org.apache.hadoop.io.serializer.Deserializer<Writable> WritableSerialization.getDeserializer(Class<Writable> c)
           
 org.apache.hadoop.io.serializer.Serializer<Writable> WritableSerialization.getSerializer(Class<Writable> c)
           
 

Method parameters in org.apache.hadoop.io.serializer with type arguments of type Writable
 org.apache.hadoop.io.serializer.Deserializer<Writable> WritableSerialization.getDeserializer(Class<Writable> c)
           
 org.apache.hadoop.io.serializer.Serializer<Writable> WritableSerialization.getSerializer(Class<Writable> c)
           
 

Uses of Writable in org.apache.hadoop.ipc
 

Classes in org.apache.hadoop.ipc that implement Writable
 class ProtocolSignature
           
 

Methods in org.apache.hadoop.ipc that return Writable
 Writable WritableRpcEngine.Server.call(Class<?> protocol, Writable param, long receivedTime)
           
abstract  Writable Server.call(Class<?> protocol, Writable param, long receiveTime)
          Called for each call.
 Writable[] Client.call(Writable[] params, InetSocketAddress[] addresses)
          Deprecated. Use Client.call(Writable[], InetSocketAddress[], Class, UserGroupInformation, Configuration) instead
 Writable[] Client.call(Writable[] params, InetSocketAddress[] addresses, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket)
          Deprecated. Use Client.call(Writable[], InetSocketAddress[], Class, UserGroupInformation, Configuration) instead
 Writable[] Client.call(Writable[] params, InetSocketAddress[] addresses, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket, Configuration conf)
          Makes a set of calls in parallel.
 Writable Client.call(Writable param, org.apache.hadoop.ipc.Client.ConnectionId remoteId)
          Make a call, passing param, to the IPC server defined by remoteId, returning the value.
 Writable Client.call(Writable param, InetSocketAddress address)
          Deprecated. Use Client.call(Writable, ConnectionId) instead
 Writable Client.call(Writable param, InetSocketAddress addr, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket, int rpcTimeout)
          Deprecated. Use Client.call(Writable, ConnectionId) instead
 Writable Client.call(Writable param, InetSocketAddress addr, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket, int rpcTimeout, Configuration conf)
          Make a call, passing param, to the IPC server running at address which is servicing the protocol protocol, with the ticket credentials, rpcTimeout as timeout and conf as conf for this connection, returning the value.
 Writable Client.call(Writable param, InetSocketAddress addr, org.apache.hadoop.security.UserGroupInformation ticket)
          Deprecated. Use Client.call(Writable, ConnectionId) instead
 Writable Server.call(Writable param, long receiveTime)
          Deprecated. Use Server.call(Class, Writable, long) instead
 

Methods in org.apache.hadoop.ipc with parameters of type Writable
 Writable WritableRpcEngine.Server.call(Class<?> protocol, Writable param, long receivedTime)
           
abstract  Writable Server.call(Class<?> protocol, Writable param, long receiveTime)
          Called for each call.
 Writable[] Client.call(Writable[] params, InetSocketAddress[] addresses)
          Deprecated. Use Client.call(Writable[], InetSocketAddress[], Class, UserGroupInformation, Configuration) instead
 Writable[] Client.call(Writable[] params, InetSocketAddress[] addresses, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket)
          Deprecated. Use Client.call(Writable[], InetSocketAddress[], Class, UserGroupInformation, Configuration) instead
 Writable[] Client.call(Writable[] params, InetSocketAddress[] addresses, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket, Configuration conf)
          Makes a set of calls in parallel.
 Writable Client.call(Writable param, org.apache.hadoop.ipc.Client.ConnectionId remoteId)
          Make a call, passing param, to the IPC server defined by remoteId, returning the value.
 Writable Client.call(Writable param, InetSocketAddress address)
          Deprecated. Use Client.call(Writable, ConnectionId) instead
 Writable Client.call(Writable param, InetSocketAddress addr, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket, int rpcTimeout)
          Deprecated. Use Client.call(Writable, ConnectionId) instead
 Writable Client.call(Writable param, InetSocketAddress addr, Class<?> protocol, org.apache.hadoop.security.UserGroupInformation ticket, int rpcTimeout, Configuration conf)
          Make a call, passing param, to the IPC server running at address which is servicing the protocol protocol, with the ticket credentials, rpcTimeout as timeout and conf as conf for this connection, returning the value.
 Writable Client.call(Writable param, InetSocketAddress addr, org.apache.hadoop.security.UserGroupInformation ticket)
          Deprecated. Use Client.call(Writable, ConnectionId) instead
 Writable Server.call(Writable param, long receiveTime)
          Deprecated. Use Server.call(Class, Writable, long) instead
 

Constructor parameters in org.apache.hadoop.ipc with type arguments of type Writable
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, org.apache.hadoop.security.token.SecretManager<? extends org.apache.hadoop.security.token.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, org.apache.hadoop.security.token.SecretManager<? extends org.apache.hadoop.security.token.TokenIdentifier> secretManager)
           
Server(String bindAddress, int port, Class<? extends Writable> paramClass, int handlerCount, int numReaders, int queueSizePerHandler, Configuration conf, String serverName, org.apache.hadoop.security.token.SecretManager<? extends org.apache.hadoop.security.token.TokenIdentifier> secretManager, String portRangeConfig)
          Constructs a server listening on the named port and address.
 

Uses of Writable in org.apache.hadoop.record
 

Classes in org.apache.hadoop.record that implement Writable
 class Record
          Deprecated. Replaced by Avro.
 

Uses of Writable in org.apache.hadoop.record.meta
 

Classes in org.apache.hadoop.record.meta that implement Writable
 class RecordTypeInfo
          Deprecated. Replaced by Avro.
 

Uses of Writable in org.apache.hadoop.util
 

Methods in org.apache.hadoop.util with parameters of type Writable
static void ReflectionUtils.cloneWritableInto(Writable dst, Writable src)
          Deprecated. 
 

Uses of Writable in org.apache.hadoop.util.bloom
 

Classes in org.apache.hadoop.util.bloom that implement Writable
 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 © 2013 Apache Software Foundation. All Rights Reserved.