Skip navigation links
A B C D E F G H I K L M N O P R S T U V W 

A

accept(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.serde.NativeSerialization
 
array() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 

B

booleansToString(boolean[]) - Static method in class org.apache.hadoop.mapred.nativetask.util.ConfigUtil
 
BoolWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
BoolWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.BoolWritableSerializer
 
BufferPullee<IK,IV> - Class in org.apache.hadoop.mapred.nativetask.handlers
load data into a buffer signaled by a BufferPuller
BufferPullee(Class<IK>, Class<IV>, RawKeyValueIterator, NativeDataTarget) - Constructor for class org.apache.hadoop.mapred.nativetask.handlers.BufferPullee
 
BufferPuller - Class in org.apache.hadoop.mapred.nativetask.handlers
actively signal a BufferPullee to load data into buffer and receive
BufferPuller(NativeDataSource) - Constructor for class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
BufferPushee<OK,OV> - Class in org.apache.hadoop.mapred.nativetask.handlers
collect data when signaled
BufferPushee(Class<OK>, Class<OV>, RecordWriter<OK, OV>) - Constructor for class org.apache.hadoop.mapred.nativetask.handlers.BufferPushee
 
BufferPusher<K,V> - Class in org.apache.hadoop.mapred.nativetask.handlers
actively push data into a buffer and signal a BufferPushee to collect it
BufferPusher(Class<K>, Class<V>, NativeDataTarget) - Constructor for class org.apache.hadoop.mapred.nativetask.handlers.BufferPusher
 
BufferType - Enum in org.apache.hadoop.mapred.nativetask.buffer
 
byteBuffer - Variable in class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 
ByteBufferDataReader - Class in org.apache.hadoop.mapred.nativetask.buffer
read data from a input buffer
ByteBufferDataReader(InputBuffer) - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
ByteBufferDataWriter - Class in org.apache.hadoop.mapred.nativetask.buffer
DataOutputStream implementation which buffers data in a fixed-size ByteBuffer.
ByteBufferDataWriter(NativeDataTarget) - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
BytesUtil - Class in org.apache.hadoop.mapred.nativetask.util
 
BytesUtil() - Constructor for class org.apache.hadoop.mapred.nativetask.util.BytesUtil
 
BytesWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
BytesWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.BytesWritableSerializer
 
ByteWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
ByteWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.ByteWritableSerializer
 

C

call(Command, ReadWriteBuffer) - Method in interface org.apache.hadoop.mapred.nativetask.INativeHandler
call command to downstream
call(Command, ReadWriteBuffer) - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
capacity() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
close() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
close() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
close() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
close() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPullee
 
close() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
Closes the iterator so that the underlying streams can be closed.
close() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPushee
 
close() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPusher
 
close() - Method in interface org.apache.hadoop.mapred.nativetask.handlers.IDataLoader
 
close() - Method in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
close() - Method in interface org.apache.hadoop.mapred.nativetask.ICombineHandler
close handlers, buffer pullers and pushers
close() - Method in interface org.apache.hadoop.mapred.nativetask.INativeHandler
close the native handler
close() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
close() - Method in class org.apache.hadoop.mapred.nativetask.NativeMapOutputCollectorDelegator
 
collect(InputBuffer) - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPushee
 
collect(K, V, int) - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPusher
 
collect(K, V) - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPusher
 
collect(K, V, int) - Method in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
collect(K, V, int) - Method in class org.apache.hadoop.mapred.nativetask.NativeMapOutputCollectorDelegator
 
combine() - Method in interface org.apache.hadoop.mapred.nativetask.ICombineHandler
run combiner
Command - Class in org.apache.hadoop.mapred.nativetask
 
Command(int) - Constructor for class org.apache.hadoop.mapred.nativetask.Command
 
Command(int, String) - Constructor for class org.apache.hadoop.mapred.nativetask.Command
 
CommandDispatcher - Interface in org.apache.hadoop.mapred.nativetask
a CommandDispatcher receives Command from upstream and performs corresponding operations
configure(Configuration) - Static method in class org.apache.hadoop.mapred.nativetask.NativeRuntime
 
ConfigUtil - Class in org.apache.hadoop.mapred.nativetask.util
 
ConfigUtil() - Constructor for class org.apache.hadoop.mapred.nativetask.util.ConfigUtil
 
Constants - Class in org.apache.hadoop.mapred.nativetask
 
Constants() - Constructor for class org.apache.hadoop.mapred.nativetask.Constants
 
copyOf() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
create(TaskContext) - Static method in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
create(String, Configuration, DataChannel) - Static method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
createNativeObject(String) - Static method in class org.apache.hadoop.mapred.nativetask.NativeRuntime
create native object We use it to create native handlers
createNativeTaskOutput(Configuration, String) - Static method in class org.apache.hadoop.mapred.nativetask.util.OutputUtil
 

D

DataChannel - Enum in org.apache.hadoop.mapred.nativetask
 
DataInputStream - Class in org.apache.hadoop.mapred.nativetask.buffer
 
DataInputStream() - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.DataInputStream
 
DataOutputStream - Class in org.apache.hadoop.mapred.nativetask.buffer
 
DataOutputStream() - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.DataOutputStream
 
DataReceiver - Interface in org.apache.hadoop.mapred.nativetask
a DataReceiver pulls in arriving data, an example is BufferPuller
DefaultSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
DefaultSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.DefaultSerializer
 
define(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.HadoopPlatform
 
define(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.Platform
whether it's the platform that has defined a custom Java comparator NativeTask doesn't support custom Java comparators (set with mapreduce.job.output.key.comparator.class) but a platform (e.g Pig) could also set that conf and implement native comparators so we shouldn't bail out.
define(Class<?>) - Static method in class org.apache.hadoop.mapred.nativetask.Platforms
 
description() - Method in class org.apache.hadoop.mapred.nativetask.Command
 
deserialize(DataInput, int, BytesWritable) - Method in class org.apache.hadoop.mapred.nativetask.serde.BytesWritableSerializer
 
deserialize(DataInput, int, Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.DefaultSerializer
 
deserialize(DataInput, int, T) - Method in interface org.apache.hadoop.mapred.nativetask.serde.INativeSerializer
 
deserialize(DataInput, int, Text) - Method in class org.apache.hadoop.mapred.nativetask.serde.TextSerializer
 
deserializeKV(DataInputStream, SizedWritable<?>, SizedWritable<?>) - Method in interface org.apache.hadoop.mapred.nativetask.serde.IKVSerializer
 
deserializeKV(DataInputStream, SizedWritable<?>, SizedWritable<?>) - Method in class org.apache.hadoop.mapred.nativetask.serde.KVSerializer
 
DoubleWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
DoubleWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.DoubleWritableSerializer
 

E

equals(Object) - Method in class org.apache.hadoop.mapred.nativetask.Command
 

F

finishOutput() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
finishSendData() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
finishSendData() - Method in interface org.apache.hadoop.mapred.nativetask.NativeDataTarget
Sends a signal that there is no more data
FloatWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
FloatWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.FloatWritableSerializer
 
flush() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
flush() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPusher
 
flush() - Method in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
flush() - Method in class org.apache.hadoop.mapred.nativetask.NativeMapOutputCollectorDelegator
 

G

GET_COMBINE_HANDLER - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
GET_OUTPUT_INDEX_PATH - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
GET_OUTPUT_PATH - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
GET_SPILL_PATH - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
getBuff() - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
getByteBuffer() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
getByteBuffer() - Method in class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 
getConf() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
getId() - Method in interface org.apache.hadoop.mapred.nativetask.ICombineHandler
 
getInputBuffer() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
getInputBuffer() - Method in interface org.apache.hadoop.mapred.nativetask.NativeDataSource
get input buffer
getInputFile(int) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Return a local reduce input file created earlier
getInputFile(int) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Return a local reduce input file created earlier
getInputFile(int) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Return a local reduce input file created earlier
getInputFileForWrite(TaskID, long, Configuration) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Create a local reduce input file name.
getInputFileForWrite(TaskID, long, Configuration) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Create a local reduce input file name.
getInputFileForWrite(TaskID, long, Configuration) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Create a local reduce input file name.
getInputKeyClass() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
getInputValueClass() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
getInstance() - Static method in class org.apache.hadoop.mapred.nativetask.serde.NativeSerialization
 
getKey() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.BoolWritableSerializer
 
getLength(BytesWritable) - Method in class org.apache.hadoop.mapred.nativetask.serde.BytesWritableSerializer
 
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.ByteWritableSerializer
 
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.DefaultSerializer
 
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.DoubleWritableSerializer
 
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.FloatWritableSerializer
 
getLength(T) - Method in interface org.apache.hadoop.mapred.nativetask.serde.INativeSerializer
get length of data to be serialized.
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.IntWritableSerializer
 
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.LongWritableSerializer
 
getLength(Writable) - Method in class org.apache.hadoop.mapred.nativetask.serde.NullWritableSerializer
 
getLength(Text) - Method in class org.apache.hadoop.mapred.nativetask.serde.TextSerializer
 
getNativeHandler() - Method in interface org.apache.hadoop.mapred.nativetask.INativeHandler
 
getNativeHandler() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
getOutputBuffer() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
getOutputBuffer() - Method in interface org.apache.hadoop.mapred.nativetask.NativeDataTarget
Gets the output buffer.
getOutputFile() - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Return the path to local map output file created earlier
getOutputFile() - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Return the path to local map output file created earlier
getOutputFile() - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Return the path to local map output file created earlier
getOutputFileForWrite(long) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Create a local map output file name.
getOutputFileForWrite(long) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Create a local map output file name.
getOutputFileForWrite(long) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Create a local map output file name.
getOutputIndexFile() - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Return the path to a local map output index file created earlier
getOutputIndexFile() - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Return the path to a local map output index file created earlier
getOutputIndexFile() - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Return the path to a local map output index file created earlier
getOutputIndexFileForWrite(long) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Create a local map output index file name.
getOutputIndexFileForWrite(long) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Create a local map output index file name.
getOutputIndexFileForWrite(long) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Create a local map output index file name.
getOutputKeyClass() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
getOutputName(int) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
 
getOutputName(int) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
 
getOutputName(int) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
 
getOutputValueClass() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
getProgress() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
getReadPoint() - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
getSerializer(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.serde.NativeSerialization
 
getSpillFile(int) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Return a local map spill file created earlier.
getSpillFile(int) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Return a local map spill file created earlier.
getSpillFile(int) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Return a local map spill file created earlier.
getSpillFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Create a local map spill file name.
getSpillFileForWrite(int, long) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Create a local map spill file name.
getSpillFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Create a local map spill file name.
getSpillIndexFile(int) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Return a local map spill index file created earlier
getSpillIndexFile(int) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Return a local map spill index file created earlier
getSpillIndexFile(int) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Return a local map spill index file created earlier
getSpillIndexFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Create a local map spill index file name.
getSpillIndexFileForWrite(int, long) - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Create a local map spill index file name.
getSpillIndexFileForWrite(int, long) - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Create a local map spill index file name.
getTaskAttemptId() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
getTaskReporter() - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
getType() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
getType() - Method in class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 
getType() - Method in enum org.apache.hadoop.mapred.nativetask.serde.SerializationFramework
 
getValue() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
getWritePoint() - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 

H

HadoopPlatform - Class in org.apache.hadoop.mapred.nativetask
 
HadoopPlatform() - Constructor for class org.apache.hadoop.mapred.nativetask.HadoopPlatform
 
hashCode() - Method in class org.apache.hadoop.mapred.nativetask.Command
 
hasUnFlushedData() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
hasUnFlushedData() - Method in class org.apache.hadoop.mapred.nativetask.buffer.DataOutputStream
Check whether there is unflushed data stored in the stream
hasUnReadData() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
hasUnReadData() - Method in class org.apache.hadoop.mapred.nativetask.buffer.DataInputStream
 

I

ICombineHandler - Interface in org.apache.hadoop.mapred.nativetask
interacts with native side to support Java Combiner
id() - Method in class org.apache.hadoop.mapred.nativetask.Command
 
IDataLoader - Interface in org.apache.hadoop.mapred.nativetask.handlers
an IDataLoader loads data on demand
IKVSerializer - Interface in org.apache.hadoop.mapred.nativetask.serde
serializes key-value pair
INativeComparable - Interface in org.apache.hadoop.mapred.nativetask
Any key type that is comparable at native side must implement this interface.
INativeHandler - Interface in org.apache.hadoop.mapred.nativetask
A Handler accept input, and give output can be used to transfer command and data
INativeSerializer<T> - Interface in org.apache.hadoop.mapred.nativetask.serde
an INativeSerializer serializes and deserializes data transferred between Java and native.
init() - Method in class org.apache.hadoop.mapred.nativetask.HadoopPlatform
 
init(Configuration) - Method in interface org.apache.hadoop.mapred.nativetask.INativeHandler
init the native handler
init(Configuration) - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
init(MapOutputCollector.Context) - Method in class org.apache.hadoop.mapred.nativetask.NativeMapOutputCollectorDelegator
 
init() - Method in class org.apache.hadoop.mapred.nativetask.Platform
initialize a platform, where we should call registerKey
init(Configuration) - Static method in class org.apache.hadoop.mapred.nativetask.Platforms
 
InputBuffer - Class in org.apache.hadoop.mapred.nativetask.buffer
 
InputBuffer(BufferType, int) - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
InputBuffer(byte[]) - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
IntWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
IntWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.IntWritableSerializer
 
INVALID_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.util.SizedWritable
 
isNativeLibraryLoaded() - Static method in class org.apache.hadoop.mapred.nativetask.NativeRuntime
 

K

keyClassNames - Variable in class org.apache.hadoop.mapred.nativetask.Platform
 
KV_HEAD_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.serde.KVSerializer
 
KV_HEADER_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.BufferPullee
 
KV_HEADER_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
KV_HEADER_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.BufferPushee
 
KVSerializer<K,V> - Class in org.apache.hadoop.mapred.nativetask.serde
 
KVSerializer(Class<K>, Class<V>) - Constructor for class org.apache.hadoop.mapred.nativetask.serde.KVSerializer
 

L

length() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
length() - Method in class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 
length - Variable in class org.apache.hadoop.mapred.nativetask.util.SizedWritable
 
limit() - Method in class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 
load() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPullee
 
load() - Method in interface org.apache.hadoop.mapred.nativetask.handlers.IDataLoader
 
loadData() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
loadData() - Method in interface org.apache.hadoop.mapred.nativetask.NativeDataSource
load data from upstream
LocalJobOutputFiles - Class in org.apache.hadoop.mapred.nativetask.util
 
LocalJobOutputFiles(Configuration, String) - Constructor for class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
 
LongWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
LongWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.LongWritableSerializer
 

M

MAP_SORT_CLASS - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
MAPRED_COMBINER_CLASS - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 

N

name() - Method in class org.apache.hadoop.mapred.nativetask.HadoopPlatform
 
NAME - Static variable in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
name() - Method in interface org.apache.hadoop.mapred.nativetask.INativeHandler
 
name() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
name() - Method in class org.apache.hadoop.mapred.nativetask.Platform
 
NATIVE_ASYNC_PROCESSOR_BUFFER_KB_DEFAULT - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_CLASS_LIBRARY - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_CLASS_LIBRARY_BUILDIN - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_CLASS_LIBRARY_CUSTOM - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_HADOOP_VERSION - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_LOG_DEVICE - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_MAPOUT_KEY_COMPARATOR - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_PROCESSOR_BUFFER_KB - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_PROCESSOR_BUFFER_KB_DEFAULT - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_STATUS_UPDATE_INTERVAL - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_STATUS_UPDATE_INTERVAL_DEFVAL - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
NATIVE_TASK_OUTPUT_MANAGER - Static variable in class org.apache.hadoop.mapred.nativetask.util.OutputUtil
 
NativeBatchProcessor - Class in org.apache.hadoop.mapred.nativetask
used to create channel, transfer data and command between Java and native
NativeBatchProcessor(String, InputBuffer, OutputBuffer) - Constructor for class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
NativeCollectorOnlyHandler<K,V> - Class in org.apache.hadoop.mapred.nativetask.handlers
Java Record Reader + Java Mapper + Native Collector
NativeCollectorOnlyHandler(TaskContext, INativeHandler, BufferPusher<K, V>, ICombineHandler) - Constructor for class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
NativeDataSource - Interface in org.apache.hadoop.mapred.nativetask
NativeDataSource loads data from upstream
NativeDataTarget - Interface in org.apache.hadoop.mapred.nativetask
NativeDataTarge sends data to downstream
NativeMapOutputCollectorDelegator<K,V> - Class in org.apache.hadoop.mapred.nativetask
native map output collector wrapped in Java interface
NativeMapOutputCollectorDelegator() - Constructor for class org.apache.hadoop.mapred.nativetask.NativeMapOutputCollectorDelegator
 
NativeRuntime - Class in org.apache.hadoop.mapred.nativetask
This class stands for the native runtime It has three functions: 1.
NativeRuntime() - Constructor for class org.apache.hadoop.mapred.nativetask.NativeRuntime
 
NativeSerialization - Class in org.apache.hadoop.mapred.nativetask.serde
 
NativeSerialization() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.NativeSerialization
 
NativeTaskOutput - Interface in org.apache.hadoop.mapred.nativetask.util
base class of output files manager.
NativeTaskOutputFiles - Class in org.apache.hadoop.mapred.nativetask.util
Manipulate the working area for the transient store for maps and reduces.
NativeTaskOutputFiles(Configuration, String) - Constructor for class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
 
next() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
NullWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
NullWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.NullWritableSerializer
 

O

onCall(Command, ReadWriteBuffer) - Method in interface org.apache.hadoop.mapred.nativetask.CommandDispatcher
 
onCall(Command, ReadWriteBuffer) - Method in class org.apache.hadoop.mapred.nativetask.handlers.NativeCollectorOnlyHandler
 
org.apache.hadoop.mapred.nativetask - package org.apache.hadoop.mapred.nativetask
 
org.apache.hadoop.mapred.nativetask.buffer - package org.apache.hadoop.mapred.nativetask.buffer
 
org.apache.hadoop.mapred.nativetask.handlers - package org.apache.hadoop.mapred.nativetask.handlers
 
org.apache.hadoop.mapred.nativetask.serde - package org.apache.hadoop.mapred.nativetask.serde
 
org.apache.hadoop.mapred.nativetask.util - package org.apache.hadoop.mapred.nativetask.util
 
OutputBuffer - Class in org.apache.hadoop.mapred.nativetask.buffer
 
OutputBuffer(BufferType, int) - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 
OutputBuffer(byte[]) - Constructor for class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 
OutputUtil - Class in org.apache.hadoop.mapred.nativetask.util
 
OutputUtil() - Constructor for class org.apache.hadoop.mapred.nativetask.util.OutputUtil
 

P

Platform - Class in org.apache.hadoop.mapred.nativetask
Base class for platforms.
Platform() - Constructor for class org.apache.hadoop.mapred.nativetask.Platform
 
Platforms - Class in org.apache.hadoop.mapred.nativetask
this class will load in and init all platforms on classpath it is also the facade to check for key type support and other platform methods
Platforms() - Constructor for class org.apache.hadoop.mapred.nativetask.Platforms
 
position() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
position(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 

R

read() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
read(byte[], int, int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readBoolean() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readByte() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readBytes() - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
readChar() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readDouble() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readFields(DataInputBuffer) - Method in class org.apache.hadoop.mapred.nativetask.util.SizedWritable
 
readFloat() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readFully(byte[]) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readFully(byte[], int, int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readInt() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readInt() - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
readLine() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readLong() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readLong() - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
readShort() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readString() - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
readUnsignedByte() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readUnsignedShort() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
readUTF() - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
ReadWriteBuffer - Class in org.apache.hadoop.mapred.nativetask.util
 
ReadWriteBuffer(int) - Constructor for class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
ReadWriteBuffer() - Constructor for class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
ReadWriteBuffer(byte[]) - Constructor for class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
receiveData() - Method in interface org.apache.hadoop.mapred.nativetask.DataReceiver
Send a signal to the receiver that the data arrives.
receiveData() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
register(String, Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.serde.NativeSerialization
 
registerKey(String, Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.Platform
associate a key class with its serializer and platform
registerLibrary(String, String) - Static method in class org.apache.hadoop.mapred.nativetask.NativeRuntime
Register a customized library
releaseNativeObject(long) - Static method in class org.apache.hadoop.mapred.nativetask.NativeRuntime
destroy native object We use to destory native handlers
remaining() - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
removeAll() - Method in class org.apache.hadoop.mapred.nativetask.util.LocalJobOutputFiles
Removes all of the files related to a task.
removeAll() - Method in interface org.apache.hadoop.mapred.nativetask.util.NativeTaskOutput
Removes all of the files related to a task.
removeAll() - Method in class org.apache.hadoop.mapred.nativetask.util.NativeTaskOutputFiles
Removes all of the files related to a task.
reportStatus(Task.TaskReporter) - Static method in class org.apache.hadoop.mapred.nativetask.NativeRuntime
Get the status report from native space
reset(InputBuffer) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
reset() - Method in class org.apache.hadoop.mapred.nativetask.handlers.BufferPuller
 
reset() - Method in class org.apache.hadoop.mapred.nativetask.serde.NativeSerialization
 
reset(byte[]) - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
reset(T) - Method in class org.apache.hadoop.mapred.nativetask.util.SizedWritable
 
rewind(int, int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.InputBuffer
 
rewind() - Method in class org.apache.hadoop.mapred.nativetask.buffer.OutputBuffer
 

S

sendData() - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
sendData() - Method in interface org.apache.hadoop.mapred.nativetask.NativeDataTarget
Sends a signal to indicate that the data has been stored in output buffer
SERIALIZATION_FRAMEWORK - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
SerializationFramework - Enum in org.apache.hadoop.mapred.nativetask.serde
 
serialize(BytesWritable, DataOutput) - Method in class org.apache.hadoop.mapred.nativetask.serde.BytesWritableSerializer
 
serialize(Writable, DataOutput) - Method in class org.apache.hadoop.mapred.nativetask.serde.DefaultSerializer
 
serialize(T, DataOutput) - Method in interface org.apache.hadoop.mapred.nativetask.serde.INativeSerializer
 
serialize(Text, DataOutput) - Method in class org.apache.hadoop.mapred.nativetask.serde.TextSerializer
 
serializeKV(DataOutputStream, SizedWritable<?>, SizedWritable<?>) - Method in interface org.apache.hadoop.mapred.nativetask.serde.IKVSerializer
 
serializeKV(DataOutputStream, SizedWritable<?>, SizedWritable<?>) - Method in class org.apache.hadoop.mapred.nativetask.serde.KVSerializer
 
serializePartitionKV(DataOutputStream, int, SizedWritable<?>, SizedWritable<?>) - Method in interface org.apache.hadoop.mapred.nativetask.serde.IKVSerializer
 
serializePartitionKV(DataOutputStream, int, SizedWritable<?>, SizedWritable<?>) - Method in class org.apache.hadoop.mapred.nativetask.serde.KVSerializer
 
serializer - Variable in class org.apache.hadoop.mapred.nativetask.handlers.BufferPullee
 
setCommandDispatcher(CommandDispatcher) - Method in interface org.apache.hadoop.mapred.nativetask.INativeHandler
 
setCommandDispatcher(CommandDispatcher) - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
setDataReceiver(DataReceiver) - Method in class org.apache.hadoop.mapred.nativetask.NativeBatchProcessor
 
setDataReceiver(DataReceiver) - Method in interface org.apache.hadoop.mapred.nativetask.NativeDataSource
set listener.
setInputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
setInputValueClass(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
setOutputKeyClass(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
setOutputValueClass(Class<?>) - Method in class org.apache.hadoop.mapred.nativetask.TaskContext
 
setReadPoint(int) - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
setWritePoint(int) - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
shortOfSpace(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
shortOfSpace(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.DataOutputStream
Check whether this buffer has enough space to store length of bytes
SizedWritable<T> - Class in org.apache.hadoop.mapred.nativetask.util
 
SizedWritable(Class<?>) - Constructor for class org.apache.hadoop.mapred.nativetask.util.SizedWritable
 
SIZEOF_KEY_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
SIZEOF_KV_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
SIZEOF_PARTITION_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
SIZEOF_VALUE_LENGTH - Static variable in class org.apache.hadoop.mapred.nativetask.Constants
 
skipBytes(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataReader
 
support(String, INativeSerializer<?>, JobConf) - Method in class org.apache.hadoop.mapred.nativetask.HadoopPlatform
 
support(String, INativeSerializer<?>, JobConf) - Method in class org.apache.hadoop.mapred.nativetask.Platform
whether a platform supports a specific key should at least satisfy two conditions 1.
support(String, INativeSerializer<?>, JobConf) - Static method in class org.apache.hadoop.mapred.nativetask.Platforms
 
supportsCompressionCodec(byte[]) - Static method in class org.apache.hadoop.mapred.nativetask.NativeRuntime
Check whether the native side has compression codec support built in

T

TaskContext - Class in org.apache.hadoop.mapred.nativetask
 
TaskContext(JobConf, Class<?>, Class<?>, Class<?>, Class<?>, Task.TaskReporter, TaskAttemptID) - Constructor for class org.apache.hadoop.mapred.nativetask.TaskContext
 
TextSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
TextSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.TextSerializer
 
toBytes(boolean) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Convert a boolean to a byte array.
toBytes(float) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
 
toBytes(double) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Serialize a double as the IEEE 754 double format output.
toBytes(Configuration) - Static method in class org.apache.hadoop.mapred.nativetask.util.ConfigUtil
 
toDouble(byte[]) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
 
toDouble(byte[], int) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
 
toFloat(byte[]) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Presumes float encoded as IEEE 754 floating-point "single format"
toFloat(byte[], int) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Presumes float encoded as IEEE 754 floating-point "single format"
toInt(byte[], int) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Convert a big-endian integer from a byte array to a primitive value.
toLong(byte[], int) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Converts a big-endian byte array to a long value.
toStringBinary(byte[]) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Write a printable representation of a byte array.
toStringBinary(byte[], int, int) - Static method in class org.apache.hadoop.mapred.nativetask.util.BytesUtil
Write a printable representation of a byte array.

U

updateLength(SizedWritable<?>, SizedWritable<?>) - Method in interface org.apache.hadoop.mapred.nativetask.serde.IKVSerializer
update the length field of SizedWritable
updateLength(SizedWritable<?>, SizedWritable<?>) - Method in class org.apache.hadoop.mapred.nativetask.serde.KVSerializer
 

V

v - Variable in class org.apache.hadoop.mapred.nativetask.util.SizedWritable
 
valueOf(String) - Static method in enum org.apache.hadoop.mapred.nativetask.buffer.BufferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.nativetask.DataChannel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.mapred.nativetask.serde.SerializationFramework
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.hadoop.mapred.nativetask.buffer.BufferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapred.nativetask.DataChannel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.mapred.nativetask.serde.SerializationFramework
Returns an array containing the constants of this enum type, in the order they are declared.
VIntWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
VIntWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.VIntWritableSerializer
 
VLongWritableSerializer - Class in org.apache.hadoop.mapred.nativetask.serde
 
VLongWritableSerializer() - Constructor for class org.apache.hadoop.mapred.nativetask.serde.VLongWritableSerializer
 

W

write(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
write(byte[], int, int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeBoolean(boolean) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeByte(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeBytes(String) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeBytes(byte[], int, int) - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
writeChar(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeChars(String) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeDouble(double) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeFloat(float) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeInt(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeInt(int) - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
writeLong(long) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeLong(long) - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
writeShort(int) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
writeString(String) - Method in class org.apache.hadoop.mapred.nativetask.util.ReadWriteBuffer
 
writeUTF(String) - Method in class org.apache.hadoop.mapred.nativetask.buffer.ByteBufferDataWriter
 
A B C D E F G H I K L M N O P R S T U V W 
Skip navigation links

Copyright © 2008–2018 Apache Software Foundation. All rights reserved.