|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use Writable | |
---|---|
org.apache.hadoop.conf | Configuration of system parameters. |
org.apache.hadoop.contrib.index.example | |
org.apache.hadoop.contrib.index.mapred | |
org.apache.hadoop.contrib.utils.join | |
org.apache.hadoop.examples | Hadoop example code. |
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.mapred | A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner. |
org.apache.hadoop.mapred.join | Given a set of sorted datasets keyed with the same class and yielding equal partitions, it is possible to effect a join of those datasets prior to the map. |
org.apache.hadoop.mapred.lib | Library of generally useful mappers, reducers, and partitioners. |
org.apache.hadoop.mapred.lib.aggregate | Classes for performing various counting and aggregations. |
org.apache.hadoop.mapred.lib.db | org.apache.hadoop.mapred.lib.db Package |
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.lib.db | |
org.apache.hadoop.mapreduce.lib.output | |
org.apache.hadoop.mapreduce.security.token | |
org.apache.hadoop.mapreduce.security.token.delegation | |
org.apache.hadoop.mapreduce.split | |
org.apache.hadoop.record | 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.streaming.io | |
org.apache.hadoop.typedbytes | Typed bytes are sequences of bytes in which the first byte is a type code. |
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.contrib.index.example |
---|
Classes in org.apache.hadoop.contrib.index.example that implement Writable | |
---|---|
class |
LineDocTextAndOp
This class represents an operation. |
Uses of Writable in org.apache.hadoop.contrib.index.mapred |
---|
Classes in org.apache.hadoop.contrib.index.mapred with type parameters of type Writable | |
---|---|
interface |
ILocalAnalysis<K extends WritableComparable,V extends Writable>
Application specific local analysis. |
class |
IndexUpdateMapper<K extends WritableComparable,V extends Writable>
This class applies local analysis on a key-value pair and then convert the result docid-operation pair to a shard-and-intermediate form pair. |
Classes in org.apache.hadoop.contrib.index.mapred that implement Writable | |
---|---|
class |
DocumentAndOp
This class represents an indexing operation. |
class |
DocumentID
The class represents a document id, which is of type text. |
class |
IntermediateForm
An intermediate form for one or more parsed Lucene documents and/or delete terms. |
class |
Shard
This class represents the metadata of a shard. |
Methods in org.apache.hadoop.contrib.index.mapred that return types with arguments of type Writable | |
---|---|
static Class<? extends Writable> |
IndexUpdateMapper.getMapOutputValueClass()
Get the map output value class. |
static Class<? extends Writable> |
IndexUpdateReducer.getOutputValueClass()
Get the reduce output value class. |
Uses of Writable in org.apache.hadoop.contrib.utils.join |
---|
Classes in org.apache.hadoop.contrib.utils.join that implement Writable | |
---|---|
class |
TaggedMapOutput
This abstract class serves as the base class for the values that flow from the mappers to the reducers in a data join job. |
Methods in org.apache.hadoop.contrib.utils.join that return Writable | |
---|---|
abstract Writable |
TaggedMapOutput.getData()
|
Uses of Writable in org.apache.hadoop.examples |
---|
Classes in org.apache.hadoop.examples that implement Writable | |
---|---|
static class |
MultiFileWordCount.WordOffset
This record keeps <filename,offset> pairs. |
static class |
SecondarySort.IntPair
Define a pair of integers that are writable. |
static class |
SleepJob.EmptySplit
|
Method parameters in org.apache.hadoop.examples with type arguments of type Writable | |
---|---|
void |
PiEstimator.PiReducer.reduce(BooleanWritable isInside,
Iterator<LongWritable> values,
OutputCollector<WritableComparable<?>,Writable> output,
Reporter reporter)
Accumulate number of points inside/outside results from the mappers. |
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 |
MD5MD5CRC32FileChecksum
MD5 of MD5 of CRC32. |
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. |
class |
PermissionStatus
Store permission related information. |
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 |
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 |
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 |
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 |
UTF8
Deprecated. replaced by Text |
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
|
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 |
GenericWritable.get()
Return the wrapped instance. |
Writable[][] |
TwoDArrayWritable.get()
|
Writable[] |
ArrayWritable.get()
|
Writable |
ArrayFile.Reader.get(long n,
Writable value)
Return the n th value in the file. |
Writable |
MapWritable.get(Object key)
|
Writable |
SortedMapWritable.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 |
MapWritable.remove(Object key)
|
Writable |
SortedMapWritable.remove(Object key)
|
Methods in org.apache.hadoop.io that return types with arguments of type Writable | |
---|---|
Set<Map.Entry<Writable,Writable>> |
MapWritable.entrySet()
|
Set<Map.Entry<Writable,Writable>> |
MapWritable.entrySet()
|
Set<Map.Entry<WritableComparable,Writable>> |
SortedMapWritable.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> |
MapWritable.values()
|
Collection<Writable> |
SortedMapWritable.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 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'. |
Writable |
ArrayFile.Reader.next(Writable value)
Read and return the next value in the file. |
boolean |
SequenceFile.Reader.next(Writable key)
Read the next key in the file into key , skipping its
value. |
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)
|
Uses of Writable in org.apache.hadoop.io.serializer |
---|
Methods in org.apache.hadoop.io.serializer that return types with arguments of type Writable | |
---|---|
Deserializer<Writable> |
WritableSerialization.getDeserializer(Class<Writable> c)
|
Serializer<Writable> |
WritableSerialization.getSerializer(Class<Writable> c)
|
Method parameters in org.apache.hadoop.io.serializer with type arguments of type Writable | |
---|---|
Deserializer<Writable> |
WritableSerialization.getDeserializer(Class<Writable> c)
|
Serializer<Writable> |
WritableSerialization.getSerializer(Class<Writable> c)
|
Uses of Writable in org.apache.hadoop.ipc |
---|
Methods in org.apache.hadoop.ipc that return Writable | |
---|---|
abstract Writable |
Server.call(Class<?> protocol,
Writable param,
long receiveTime)
Called for each call. |
Writable |
RPC.Server.call(Class<?> protocol,
Writable param,
long receivedTime)
|
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,
UserGroupInformation ticket)
Deprecated. Use Client.call(Writable[], InetSocketAddress[],
Class, UserGroupInformation, Configuration) instead |
Writable[] |
Client.call(Writable[] params,
InetSocketAddress[] addresses,
Class<?> protocol,
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,
UserGroupInformation ticket,
int rpcTimeout)
Deprecated. Use Client.call(Writable, ConnectionId) instead |
Writable |
Client.call(Writable param,
InetSocketAddress addr,
Class<?> protocol,
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 configuration for this connection, returning the
value. |
Writable |
Client.call(Writable param,
InetSocketAddress addr,
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 | |
---|---|
abstract Writable |
Server.call(Class<?> protocol,
Writable param,
long receiveTime)
Called for each call. |
Writable |
RPC.Server.call(Class<?> protocol,
Writable param,
long receivedTime)
|
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,
UserGroupInformation ticket)
Deprecated. Use Client.call(Writable[], InetSocketAddress[],
Class, UserGroupInformation, Configuration) instead |
Writable[] |
Client.call(Writable[] params,
InetSocketAddress[] addresses,
Class<?> protocol,
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,
UserGroupInformation ticket,
int rpcTimeout)
Deprecated. Use Client.call(Writable, ConnectionId) instead |
Writable |
Client.call(Writable param,
InetSocketAddress addr,
Class<?> protocol,
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 configuration for this connection, returning the
value. |
Writable |
Client.call(Writable param,
InetSocketAddress addr,
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. |
|
Server(String bindAddress,
int port,
Class<? extends Writable> paramClass,
int handlerCount,
Configuration conf)
|
|
Server(String bindAddress,
int port,
Class<? extends Writable> paramClass,
int handlerCount,
Configuration conf,
String serverName)
|
|
Server(String bindAddress,
int port,
Class<? extends Writable> paramClass,
int handlerCount,
Configuration conf,
String serverName,
SecretManager<? extends TokenIdentifier> secretManager)
Constructs a server listening on the named port and address. |
Uses of Writable in org.apache.hadoop.mapred |
---|
Subinterfaces of Writable in org.apache.hadoop.mapred | |
---|---|
interface |
InputSplit
InputSplit represents the data to be processed by an
individual Mapper . |
Classes in org.apache.hadoop.mapred that implement Writable | |
---|---|
class |
ClusterStatus
Status information on the current state of the Map-Reduce cluster. |
class |
Counters
A set of named counters. |
static class |
Counters.Counter
A counter record, comprising its name and value. |
class |
Counters.Group
Group of counters, comprising of counters from a particular
counter Enum class. |
class |
FileSplit
A section of an input file. |
class |
JobConf
A map/reduce job configuration. |
class |
JobProfile
A JobProfile is a MapReduce primitive. |
class |
JobQueueInfo
Class that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework. |
class |
JobStatus
Describes the current status of a job. |
class |
JvmTask
|
class |
MapTaskCompletionEventsUpdate
A class that represents the communication between the tasktracker and child tasks w.r.t the map task completion events. |
class |
MultiFileSplit
Deprecated. Use CombineFileSplit instead |
class |
QueueAclsInfo
Class to encapsulate Queue ACLs for a particular user. |
class |
Task
Base class for tasks. |
class |
TaskCompletionEvent
This is used to track task completion events on job tracker. |
class |
TaskReport
A report on the state of a task. |
class |
TaskStatus
Describes the current status of a task. |
class |
TaskTrackerStatus
A TaskTrackerStatus is a MapReduce primitive. |
Methods in org.apache.hadoop.mapred with type parameters of type Writable | ||
---|---|---|
static
|
MapFileOutputFormat.getEntry(MapFile.Reader[] readers,
Partitioner<K,V> partitioner,
K key,
V value)
Get an entry from output generated by this class. |
Methods in org.apache.hadoop.mapred that return Writable | ||
---|---|---|
static
|
MapFileOutputFormat.getEntry(MapFile.Reader[] readers,
Partitioner<K,V> partitioner,
K key,
V value)
Get an entry from output generated by this class. |
Methods in org.apache.hadoop.mapred that return types with arguments of type Writable | |
---|---|
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 |
Uses of Writable in org.apache.hadoop.mapred.join |
---|
Classes in org.apache.hadoop.mapred.join with type parameters of type Writable | |
---|---|
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. |
static class |
ResetableIterator.EMPTY<U extends Writable>
|
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. |
Classes in org.apache.hadoop.mapred.join that implement Writable | |
---|---|
class |
CompositeInputSplit
This InputSplit contains a set of child InputSplits. |
class |
TupleWritable
Writable type storing multiple Writable s. |
Methods in org.apache.hadoop.mapred.join that return Writable | |
---|---|
Writable |
TupleWritable.get(int i)
Get ith Writable from Tuple. |
Methods in org.apache.hadoop.mapred.join that return types with arguments of type Writable | |
---|---|
Iterator<Writable> |
TupleWritable.iterator()
Return an iterator over the elements in this tuple. |
Constructors in org.apache.hadoop.mapred.join with parameters of type Writable | |
---|---|
TupleWritable(Writable[] vals)
Initialize tuple with storage; unknown whether any of them contain "written" values. |
Uses of Writable in org.apache.hadoop.mapred.lib |
---|
Classes in org.apache.hadoop.mapred.lib that implement Writable | |
---|---|
class |
CombineFileSplit
A sub-collection of input files. |
Methods in org.apache.hadoop.mapred.lib that return types with arguments of type Writable | |
---|---|
static Class<? extends Writable> |
MultipleOutputs.getNamedOutputValueClass(JobConf conf,
String namedOutput)
Returns the value class for a named output. |
Uses of Writable in org.apache.hadoop.mapred.lib.aggregate |
---|
Classes in org.apache.hadoop.mapred.lib.aggregate with type parameters of type Writable | |
---|---|
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. |
Uses of Writable in org.apache.hadoop.mapred.lib.db |
---|
Classes in org.apache.hadoop.mapred.lib.db that implement Writable | |
---|---|
protected static class |
DBInputFormat.DBInputSplit
A InputSplit that spans a set of rows |
static class |
DBInputFormat.NullDBWritable
A Class that does nothing, implementing DBWritable |
Uses of Writable in org.apache.hadoop.mapreduce |
---|
Classes in org.apache.hadoop.mapreduce that implement Writable | |
---|---|
class |
ClusterMetrics
Status information on the current state of the Map-Reduce cluster. |
class |
Counter
A named counter that tracks the progress of a map/reduce job. |
class |
CounterGroup
A group of Counter s that logically belong together. |
class |
ID
A general identifier, which internally stores the id as an integer. |
class |
JobID
JobID represents the immutable and unique identifier for the job. |
class |
TaskAttemptID
TaskAttemptID represents the immutable and unique identifier for a task attempt. |
class |
TaskID
TaskID represents the immutable and unique identifier for a Map or Reduce Task. |
Uses of Writable in org.apache.hadoop.mapreduce.lib.db |
---|
Classes in org.apache.hadoop.mapreduce.lib.db that implement Writable | |
---|---|
static class |
DataDrivenDBInputFormat.DataDrivenDBInputSplit
A InputSplit that spans a set of rows |
Uses of Writable in org.apache.hadoop.mapreduce.lib.output |
---|
Methods in org.apache.hadoop.mapreduce.lib.output that return types with arguments of type Writable | |
---|---|
static Class<? extends Writable> |
SequenceFileAsBinaryOutputFormat.getSequenceFileOutputValueClass(JobContext job)
Get the value class for the SequenceFile |
Uses of Writable in org.apache.hadoop.mapreduce.security.token |
---|
Classes in org.apache.hadoop.mapreduce.security.token that implement Writable | |
---|---|
class |
JobTokenIdentifier
The token identifier for job token |
Uses of Writable in org.apache.hadoop.mapreduce.security.token.delegation |
---|
Classes in org.apache.hadoop.mapreduce.security.token.delegation that implement Writable | |
---|---|
class |
DelegationTokenIdentifier
A delegation token identifier that is specific to MapReduce. |
Uses of Writable in org.apache.hadoop.mapreduce.split |
---|
Classes in org.apache.hadoop.mapreduce.split that implement Writable | |
---|---|
static class |
JobSplit.SplitMetaInfo
This represents the meta information about the task split. |
Uses of Writable in org.apache.hadoop.record |
---|
Classes in org.apache.hadoop.record that implement Writable | |
---|---|
class |
Record
Abstract class that is extended by generated classes. |
Uses of Writable in org.apache.hadoop.record.meta |
---|
Classes in org.apache.hadoop.record.meta that implement Writable | |
---|---|
class |
RecordTypeInfo
A record's Type Information object which can read/write itself. |
Uses of Writable in org.apache.hadoop.security |
---|
Classes in org.apache.hadoop.security that implement Writable | |
---|---|
class |
Credentials
A class that provides the facilities of reading and writing secret keys and Tokens. |
Uses of Writable in org.apache.hadoop.security.authorize |
---|
Classes in org.apache.hadoop.security.authorize that implement Writable | |
---|---|
class |
AccessControlList
Class representing a configured access control list. |
Uses of Writable in org.apache.hadoop.security.token |
---|
Classes in org.apache.hadoop.security.token that implement Writable | |
---|---|
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). |
Uses of Writable in org.apache.hadoop.security.token.delegation |
---|
Classes in org.apache.hadoop.security.token.delegation that implement Writable | |
---|---|
class |
AbstractDelegationTokenIdentifier
|
class |
DelegationKey
Key used for generating and verifying delegation tokens |
Uses of Writable in org.apache.hadoop.streaming.io |
---|
Methods in org.apache.hadoop.streaming.io with parameters of type Writable | |
---|---|
void |
RawBytesInputWriter.writeKey(Writable key)
|
void |
RawBytesInputWriter.writeValue(Writable value)
|
Uses of Writable in org.apache.hadoop.typedbytes |
---|
Classes in org.apache.hadoop.typedbytes that implement Writable | |
---|---|
class |
TypedBytesWritable
Writable for typed bytes. |
Methods in org.apache.hadoop.typedbytes that return Writable | |
---|---|
Writable |
TypedBytesWritableInput.read()
|
Writable |
TypedBytesWritableInput.readWritable()
|
Writable |
TypedBytesWritableInput.readWritable(Writable writable)
|
Methods in org.apache.hadoop.typedbytes that return types with arguments of type Writable | |
---|---|
Class<? extends Writable> |
TypedBytesWritableInput.readType()
|
Methods in org.apache.hadoop.typedbytes with parameters of type Writable | |
---|---|
Writable |
TypedBytesWritableInput.readWritable(Writable writable)
|
void |
TypedBytesWritableOutput.write(Writable w)
|
void |
TypedBytesWritableOutput.writeWritable(Writable w)
|
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 |
Filter
Defines the general behavior of a filter. |
class |
Key
The general behavior of a key that must be stored in a filter. |
class |
RetouchedBloomFilter
Implements a retouched Bloom filter, as defined in the CoNEXT 2006 paper. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |