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

A

additionalConfSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
addTaskEnvironment_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
archiveURIs - Variable in class org.apache.hadoop.streaming.StreamJob
 
argv_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
AutoInputFormat - Class in org.apache.hadoop.streaming
An InputFormat that tries to deduce the types of the input files automatically.
AutoInputFormat() - Constructor for class org.apache.hadoop.streaming.AutoInputFormat
 

B

background_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

C

cacheArchives - Variable in class org.apache.hadoop.streaming.StreamJob
 
cacheFiles - Variable in class org.apache.hadoop.streaming.StreamJob
 
clientOut - Variable in class org.apache.hadoop.streaming.io.TextInputWriter
 
close() - Method in class org.apache.hadoop.streaming.PipeMapper
 
close() - Method in class org.apache.hadoop.streaming.PipeReducer
 
close() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Close this to future operations.
comCmd_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
config_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
configure(JobConf) - Method in class org.apache.hadoop.streaming.AutoInputFormat
 
configure(JobConf) - Method in class org.apache.hadoop.streaming.PipeMapper
 
configure(JobConf) - Method in class org.apache.hadoop.streaming.PipeMapRed
 
configure(JobConf) - Method in class org.apache.hadoop.streaming.PipeReducer
 
createJob(String[]) - Static method in class org.apache.hadoop.streaming.StreamJob
This method creates a streaming job from the given argument list.
createKey() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
 
createValue() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
 

D

debug_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
detailedUsage_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
DumpTypedBytes - Class in org.apache.hadoop.streaming
Utility program that fetches all files that match a given pattern and dumps their content to stdout as typed bytes.
DumpTypedBytes(Configuration) - Constructor for class org.apache.hadoop.streaming.DumpTypedBytes
 
DumpTypedBytes() - Constructor for class org.apache.hadoop.streaming.DumpTypedBytes
 

E

endMap(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
endMap(TreeMap, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
endRecord(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
endRecord(Record, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
endVector(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
endVector(ArrayList, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
env_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
Environment - Class in org.apache.hadoop.streaming
This is a class used to get the current environment on the host machines running the map/reduce.
Environment() - Constructor for class org.apache.hadoop.streaming.Environment
 
exitUsage(boolean) - Method in class org.apache.hadoop.streaming.StreamJob
 

F

fail(String) - Method in class org.apache.hadoop.streaming.StreamJob
 
fileExtension(String) - Method in class org.apache.hadoop.streaming.JarBuilder
 
fileURIs - Variable in class org.apache.hadoop.streaming.StreamJob
 
findInClasspath(String) - Static method in class org.apache.hadoop.streaming.StreamUtil
 
findInClasspath(String, ClassLoader) - Static method in class org.apache.hadoop.streaming.StreamUtil
 
findTab(byte[], int, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
Find the first occured tab in a UTF-8 encoded string
findTab(byte[]) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
Find the first occured tab in a UTF-8 encoded string

G

get(DataInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesInput
Get a thread-local typed bytes input for the supplied DataInput.
get(DataOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Get a thread-local typed bytes output for the supplied DataOutput.
get(TypedBytesInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Get a thread-local typed bytes record input for the supplied TypedBytesInput.
get(DataInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Get a thread-local typed bytes record input for the supplied DataInput.
get(TypedBytesOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Get a thread-local typed bytes record input for the supplied TypedBytesOutput.
get(DataOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Get a thread-local typed bytes record output for the supplied DataOutput.
get(TypedBytesInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Get a thread-local typed bytes writable input for the supplied TypedBytesInput.
get(DataInput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Get a thread-local typed bytes writable input for the supplied DataInput.
get(TypedBytesOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Get a thread-local typed bytes writable input for the supplied TypedBytesOutput.
get(DataOutput) - Static method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Get a thread-local typed bytes writable output for the supplied DataOutput.
getAbsolutePath(String) - Method in class org.apache.hadoop.streaming.PathFinder
Returns the full path name of this file if it is listed in the path
getBasePathInJarOut(String) - Method in class org.apache.hadoop.streaming.JarBuilder
 
getClientInput() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the DataInput from which the client output is read.
getClientOutput() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the DataOutput to which the client input is written.
getClusterNick() - Method in class org.apache.hadoop.streaming.StreamJob
Deprecated.
getConf() - Method in class org.apache.hadoop.streaming.DumpTypedBytes
 
getConf() - Method in class org.apache.hadoop.streaming.LoadTypedBytes
 
getConf() - Method in class org.apache.hadoop.streaming.StreamJob
 
getConf() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
getConfiguration() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the Configuration.
getContext() - Method in class org.apache.hadoop.streaming.PipeMapRed
 
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.KeyOnlyTextOutputReader
 
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.OutputReader
Returns the current key.
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
getCurrentKey() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.KeyOnlyTextOutputReader
 
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.OutputReader
Returns the current value.
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
getCurrentValue() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
getFieldSeparator() - Method in class org.apache.hadoop.streaming.PipeMapper
 
getFieldSeparator() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the field separator to be used.
getFieldSeparator() - Method in class org.apache.hadoop.streaming.PipeReducer
 
getHadoopClientHome() - Method in class org.apache.hadoop.streaming.StreamJob
 
getHost() - Method in class org.apache.hadoop.streaming.Environment
 
getInputSeparator() - Method in class org.apache.hadoop.streaming.PipeMapper
 
getInputSeparator() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the input separator to be used.
getInputSeparator() - Method in class org.apache.hadoop.streaming.PipeReducer
 
getInputWriterClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved InputWriter class.
getJobTrackerHostPort() - Method in class org.apache.hadoop.streaming.StreamJob
 
getLastOutput() - Method in class org.apache.hadoop.streaming.io.KeyOnlyTextOutputReader
 
getLastOutput() - Method in class org.apache.hadoop.streaming.io.OutputReader
Returns the last output from the client as a String.
getLastOutput() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
getLastOutput() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
getLastOutput() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
getNumOfKeyFields() - Method in class org.apache.hadoop.streaming.PipeMapper
 
getNumOfKeyFields() - Method in class org.apache.hadoop.streaming.PipeMapRed
Returns the number of key fields.
getNumOfKeyFields() - Method in class org.apache.hadoop.streaming.PipeReducer
 
getOutputKeyClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved output key class.
getOutputReaderClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved OutputReader class.
getOutputValueClass() - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Returns the resolved output value class.
getPos() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Returns the current position in the input.
getProgress() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.streaming.AutoInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.streaming.StreamInputFormat
 
getType() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Get the type code embedded in the first byte.
getURIs(String, String) - Method in class org.apache.hadoop.streaming.StreamJob
get the uris of all the files/caches
getValue() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Get the typed bytes as a Java object.
go() - Method in class org.apache.hadoop.streaming.StreamJob
Deprecated.
goodClassOrNull(Configuration, String, String) - Static method in class org.apache.hadoop.streaming.StreamUtil
It may seem strange to silently switch behaviour when a String is not a classname; the reason is simplified Usage:

H

HadoopStreaming - Class in org.apache.hadoop.streaming
The main entry point.
HadoopStreaming() - Constructor for class org.apache.hadoop.streaming.HadoopStreaming
 
hasSimpleInputSpecs_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

I

IdentifierResolver - Class in org.apache.hadoop.streaming.io
This class is used to resolve a string identifier into the required IO classes.
IdentifierResolver() - Constructor for class org.apache.hadoop.streaming.io.IdentifierResolver
 
init() - Method in class org.apache.hadoop.streaming.StreamJob
 
init() - Method in class org.apache.hadoop.streaming.StreamXmlRecordReader
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.InputWriter
Initializes the InputWriter.
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.KeyOnlyTextOutputReader
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.OutputReader
Initializes the OutputReader.
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TextInputWriter
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
initialize(PipeMapRed) - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
inputFormatSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
inputSpecs_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
InputWriter<K,V> - Class in org.apache.hadoop.streaming.io
Abstract base for classes that write the client's input.
InputWriter() - Constructor for class org.apache.hadoop.streaming.io.InputWriter
 
inReaderSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
ioSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
isLocalHadoop() - Method in class org.apache.hadoop.streaming.StreamJob
 
isLocalJobTracker(JobConf) - Static method in class org.apache.hadoop.streaming.StreamUtil
 

J

jar_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
JarBuilder - Class in org.apache.hadoop.streaming
This class is the main class for generating job.jar for Hadoop Streaming jobs.
JarBuilder() - Constructor for class org.apache.hadoop.streaming.JarBuilder
 
jc_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
jobConf_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
jobId_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

K

KEY_ONLY_TEXT_ID - Static variable in class org.apache.hadoop.streaming.io.IdentifierResolver
 
KeyOnlyTextInputWriter - Class in org.apache.hadoop.streaming.io
 
KeyOnlyTextInputWriter() - Constructor for class org.apache.hadoop.streaming.io.KeyOnlyTextInputWriter
 
KeyOnlyTextOutputReader - Class in org.apache.hadoop.streaming.io
OutputReader that reads the client's output as text, interpreting each line as a key and outputting NullWritables for values.
KeyOnlyTextOutputReader() - Constructor for class org.apache.hadoop.streaming.io.KeyOnlyTextOutputReader
 

L

lazyOutput_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
LINK_URI - Static variable in class org.apache.hadoop.streaming.StreamJob
 
listJobConfProperties() - Method in class org.apache.hadoop.streaming.StreamJob
Prints out the jobconf properties on stdout when verbose is specified.
LoadTypedBytes - Class in org.apache.hadoop.streaming
Utility program that reads typed bytes from standard input and stores them in a sequence file for which the path is given as an argument.
LoadTypedBytes(Configuration) - Constructor for class org.apache.hadoop.streaming.LoadTypedBytes
 
LoadTypedBytes() - Constructor for class org.apache.hadoop.streaming.LoadTypedBytes
 
localHadoop_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
LOG - Static variable in class org.apache.hadoop.streaming.PipeMapRed
 
LOG - Static variable in class org.apache.hadoop.streaming.StreamBaseRecordReader
 
LOG - Static variable in class org.apache.hadoop.streaming.StreamJob
 

M

main(String[]) - Static method in class org.apache.hadoop.streaming.DumpTypedBytes
 
main(String[]) - Static method in class org.apache.hadoop.streaming.HadoopStreaming
 
main(String[]) - Static method in class org.apache.hadoop.streaming.JarBuilder
Test program
main(String[]) - Static method in class org.apache.hadoop.streaming.LoadTypedBytes
 
main(String[]) - Static method in class org.apache.hadoop.streaming.PathFinder
 
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.streaming.PipeMapper
 
mapCmd_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
mapDebugSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
mapRedFinished() - Method in class org.apache.hadoop.streaming.PipeMapRed
 
merge(List, List, String) - Method in class org.apache.hadoop.streaming.JarBuilder
 
minRecWrittenToEnableSkip_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
msg(String) - Method in class org.apache.hadoop.streaming.StreamJob
 

N

next(Text, Text) - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Read a record.
next(Text, Text) - Method in class org.apache.hadoop.streaming.StreamXmlRecordReader
 
numReduceTasksSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

O

org.apache.hadoop.streaming - package org.apache.hadoop.streaming
Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g.
org.apache.hadoop.streaming.io - package org.apache.hadoop.streaming.io
 
org.apache.hadoop.typedbytes - package org.apache.hadoop.typedbytes
Typed bytes are sequences of bytes in which the first byte is a type code.
outerrThreadsThrowable - Variable in class org.apache.hadoop.streaming.PipeMapRed
 
output_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
outputFormatSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
OutputReader<K,V> - Class in org.apache.hadoop.streaming.io
Abstract base for classes that read the client's output.
OutputReader() - Constructor for class org.apache.hadoop.streaming.io.OutputReader
 
outputSingleNode_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

P

packageFiles_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
packageJobJar() - Method in class org.apache.hadoop.streaming.StreamJob
 
partitionerSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
PathFinder - Class in org.apache.hadoop.streaming
Maps a relative pathname to an absolute pathname using the PATH environment.
PathFinder() - Constructor for class org.apache.hadoop.streaming.PathFinder
Construct a PathFinder object using the path from java.class.path
PathFinder(String) - Constructor for class org.apache.hadoop.streaming.PathFinder
Construct a PathFinder object using the path from the specified system environment variable.
PipeCombiner - Class in org.apache.hadoop.streaming
 
PipeCombiner() - Constructor for class org.apache.hadoop.streaming.PipeCombiner
 
PipeMapper - Class in org.apache.hadoop.streaming
A generic Mapper bridge.
PipeMapper() - Constructor for class org.apache.hadoop.streaming.PipeMapper
 
PipeMapRed - Class in org.apache.hadoop.streaming
Shared functionality for PipeMapper, PipeReducer.
PipeMapRed() - Constructor for class org.apache.hadoop.streaming.PipeMapRed
 
PipeMapRunner<K1,V1,K2,V2> - Class in org.apache.hadoop.streaming
 
PipeMapRunner() - Constructor for class org.apache.hadoop.streaming.PipeMapRunner
 
PipeReducer - Class in org.apache.hadoop.streaming
A generic Reducer bridge.
PipeReducer() - Constructor for class org.apache.hadoop.streaming.PipeReducer
 
prependPathComponent(String) - Method in class org.apache.hadoop.streaming.PathFinder
Appends the specified component to the path list
printUsage - Variable in class org.apache.hadoop.streaming.StreamJob
 

R

RAW_BYTES_ID - Static variable in class org.apache.hadoop.streaming.io.IdentifierResolver
 
RawBytesInputWriter - Class in org.apache.hadoop.streaming.io
InputWriter that writes the client's input as raw bytes.
RawBytesInputWriter() - Constructor for class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
RawBytesOutputReader - Class in org.apache.hadoop.streaming.io
OutputReader that reads the client's output as raw bytes.
RawBytesOutputReader() - Constructor for class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
read() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads a typed bytes sequence and converts it to a Java object.
read() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readArray(ArrayWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readArray() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBool() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the boolean following a Type.BOOL code.
readBool(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readBoolean(BooleanWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBoolean() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBuffer(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readByte() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the byte following a Type.BYTE code.
readByte(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readByte(ByteWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readByte() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBytes() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the bytes following a Type.BYTES code.
readBytes(BytesWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readBytes() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readDouble() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the double following a Type.DOUBLE code.
readDouble(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readDouble(DoubleWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readDouble() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readFloat() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the float following a Type.FLOAT code.
readFloat(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readFloat(FloatWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readFloat() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the integer following a Type.INT code.
readInt(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readInt(IntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readKeyValue() - Method in class org.apache.hadoop.streaming.io.KeyOnlyTextOutputReader
 
readKeyValue() - Method in class org.apache.hadoop.streaming.io.OutputReader
Read the next key/value pair outputted by the client.
readKeyValue() - Method in class org.apache.hadoop.streaming.io.RawBytesOutputReader
 
readKeyValue() - Method in class org.apache.hadoop.streaming.io.TextOutputReader
 
readKeyValue() - Method in class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
readLine(LineReader, Text) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
Read a utf8 encoded line from a data input stream.
readList() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the list following a Type.LIST code.
readLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the long following a Type.LONG code.
readLong(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readLong(LongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the map following a Type.MAP code.
readMap(MapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readMapHeader() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the header following a Type.MAP code.
readRaw() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads a typed bytes sequence.
readRawBool() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.BOOL code.
readRawByte() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw byte following a Type.BYTE code.
readRawBytes(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a custom code.
readRawBytes() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.BYTES code.
readRawDouble() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.DOUBLE code.
readRawFloat() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.FLOAT code.
readRawInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.INT code.
readRawList() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.LIST code.
readRawLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.LONG code.
readRawMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.MAP code.
readRawString() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.STRING code.
readRawVector() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the raw bytes following a Type.VECTOR code.
readSortedMap(SortedMapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readSortedMap() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readString() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the string following a Type.STRING code.
readString(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
readText(Text) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readText() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readType() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads a type byte and returns the corresponding Type.
readType() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVector() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the vector following a Type.VECTOR code.
readVectorHeader() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Reads the header following a Type.VECTOR code.
readVInt(VIntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVInt() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVLong(VLongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readVLong() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readWritable(Writable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
readWritable() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
redCmd_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.streaming.PipeReducer
 
reduceDebugSpec_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
regexpEscape(String) - Static method in class org.apache.hadoop.streaming.StreamUtil
 
resolve(String) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Resolves a given identifier.
run(String[]) - Method in class org.apache.hadoop.streaming.DumpTypedBytes
The main driver for DumpTypedBytes.
run(String[]) - Method in class org.apache.hadoop.streaming.LoadTypedBytes
The main driver for LoadTypedBytes.
run(RecordReader<K1, V1>, OutputCollector<K2, V2>, Reporter) - Method in class org.apache.hadoop.streaming.PipeMapRunner
 
run(String[]) - Method in class org.apache.hadoop.streaming.StreamJob
 
running_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

S

seekNextRecordBoundary() - Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
Implementation should seek forward in_ to the first byte of the next record.
seekNextRecordBoundary() - Method in class org.apache.hadoop.streaming.StreamXmlRecordReader
 
seenPrimary_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
setConf(Configuration) - Method in class org.apache.hadoop.streaming.DumpTypedBytes
 
setConf(Configuration) - Method in class org.apache.hadoop.streaming.LoadTypedBytes
 
setConf(Configuration) - Method in class org.apache.hadoop.streaming.StreamJob
 
setConf(Configuration) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableInput
 
setInputWriterClass(Class<? extends InputWriter>) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the InputWriter class.
setJobConf() - Method in class org.apache.hadoop.streaming.StreamJob
 
setOutputKeyClass(Class) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the output key class class.
setOutputReaderClass(Class<? extends OutputReader>) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the OutputReader class.
setOutputValueClass(Class) - Method in class org.apache.hadoop.streaming.io.IdentifierResolver
Sets the output value class.
setValue(Object) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Set the typed bytes from a given Java object.
setVerbose(boolean) - Method in class org.apache.hadoop.streaming.JarBuilder
 
shippedCanonFiles_ - Variable in class org.apache.hadoop.streaming.StreamJob
 
skipType() - Method in class org.apache.hadoop.typedbytes.TypedBytesInput
Skips a type byte.
splitKeyVal(byte[], int, int, Text, Text, int, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
splitKeyVal(byte[], int, int, Text, Text, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
splitKeyVal(byte[], Text, Text, int, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
splitKeyVal(byte[], Text, Text, int) - Static method in class org.apache.hadoop.streaming.StreamKeyValUtil
split a UTF-8 byte array into key and value assuming that the delimilator is at splitpos.
startMap(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
startMap(TreeMap, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
startRecord(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
startRecord(Record, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
startVector(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordInput
 
startVector(ArrayList, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
StreamBaseRecordReader - Class in org.apache.hadoop.streaming
Shared functionality for hadoopStreaming formats.
StreamBaseRecordReader(FSDataInputStream, FileSplit, Reporter, JobConf, FileSystem) - Constructor for class org.apache.hadoop.streaming.StreamBaseRecordReader
 
StreamInputFormat - Class in org.apache.hadoop.streaming
An input format that selects a RecordReader based on a JobConf property.
StreamInputFormat() - Constructor for class org.apache.hadoop.streaming.StreamInputFormat
 
StreamJob - Class in org.apache.hadoop.streaming
All the client-side work happens here.
StreamJob(String[], boolean) - Constructor for class org.apache.hadoop.streaming.StreamJob
Deprecated.
use StreamJob() with ToolRunner or set the Configuration using StreamJob.setConf(Configuration) and run with StreamJob.run(String[]).
StreamJob() - Constructor for class org.apache.hadoop.streaming.StreamJob
 
StreamKeyValUtil - Class in org.apache.hadoop.streaming
 
StreamKeyValUtil() - Constructor for class org.apache.hadoop.streaming.StreamKeyValUtil
 
StreamUtil - Class in org.apache.hadoop.streaming
Utilities used in streaming
StreamUtil() - Constructor for class org.apache.hadoop.streaming.StreamUtil
 
StreamXmlRecordReader - Class in org.apache.hadoop.streaming
A way to interpret XML fragments as Mapper input records.
StreamXmlRecordReader(FSDataInputStream, FileSplit, Reporter, JobConf, FileSystem) - Constructor for class org.apache.hadoop.streaming.StreamXmlRecordReader
 
submitAndMonitorJob() - Method in class org.apache.hadoop.streaming.StreamJob
 

T

TEXT_ID - Static variable in class org.apache.hadoop.streaming.io.IdentifierResolver
 
TextInputWriter - Class in org.apache.hadoop.streaming.io
InputWriter that writes the client's input as text.
TextInputWriter() - Constructor for class org.apache.hadoop.streaming.io.TextInputWriter
 
TextOutputReader - Class in org.apache.hadoop.streaming.io
OutputReader that reads the client's output as text.
TextOutputReader() - Constructor for class org.apache.hadoop.streaming.io.TextOutputReader
 
toMap() - Method in class org.apache.hadoop.streaming.Environment
 
toString() - Method in class org.apache.hadoop.typedbytes.TypedBytesWritable
Generate a suitable string representation.
Type - Enum in org.apache.hadoop.typedbytes
The possible type codes.
TYPED_BYTES_ID - Static variable in class org.apache.hadoop.streaming.io.IdentifierResolver
 
TypedBytesInput - Class in org.apache.hadoop.typedbytes
Provides functionality for reading typed bytes.
TypedBytesInput(DataInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesInput
Creates a new instance of TypedBytesInput.
TypedBytesInputWriter - Class in org.apache.hadoop.streaming.io
InputWriter that writes the client's input as typed bytes.
TypedBytesInputWriter() - Constructor for class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
TypedBytesOutput - Class in org.apache.hadoop.typedbytes
Provides functionality for writing typed bytes.
TypedBytesOutput(DataOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesOutput
Creates a new instance of TypedBytesOutput.
TypedBytesOutputReader - Class in org.apache.hadoop.streaming.io
OutputReader that reads the client's output as typed bytes.
TypedBytesOutputReader() - Constructor for class org.apache.hadoop.streaming.io.TypedBytesOutputReader
 
TypedBytesRecordInput - Class in org.apache.hadoop.typedbytes
Serializer for records that writes typed bytes.
TypedBytesRecordInput(TypedBytesInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Creates a new instance of TypedBytesRecordInput.
TypedBytesRecordInput(DataInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordInput
Creates a new instance of TypedBytesRecordInput.
TypedBytesRecordOutput - Class in org.apache.hadoop.typedbytes
Deserialized for records that reads typed bytes.
TypedBytesRecordOutput(TypedBytesOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Creates a new instance of TypedBytesRecordOutput.
TypedBytesRecordOutput(DataOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
Creates a new instance of TypedBytesRecordOutput.
TypedBytesWritable - Class in org.apache.hadoop.typedbytes
Writable for typed bytes.
TypedBytesWritable() - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritable
Create a TypedBytesWritable.
TypedBytesWritable(byte[]) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritable
Create a TypedBytesWritable with a given byte array as initial value.
TypedBytesWritableInput - Class in org.apache.hadoop.typedbytes
Provides functionality for reading typed bytes as Writable objects.
TypedBytesWritableInput(TypedBytesInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Creates a new instance of TypedBytesWritableInput.
TypedBytesWritableInput(DataInput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableInput
Creates a new instance of TypedBytesWritableInput.
TypedBytesWritableOutput - Class in org.apache.hadoop.typedbytes
Provides functionality for writing Writable objects as typed bytes.
TypedBytesWritableOutput(TypedBytesOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Creates a new instance of TypedBytesWritableOutput.
TypedBytesWritableOutput(DataOutput) - Constructor for class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
Creates a new instance of TypedBytesWritableOutput.

V

valueOf(String) - Static method in enum org.apache.hadoop.typedbytes.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.hadoop.typedbytes.Type
Returns an array containing the constants of this enum type, in the order they are declared.
verbose - Variable in class org.apache.hadoop.streaming.JarBuilder
 
verbose_ - Variable in class org.apache.hadoop.streaming.StreamJob
 

W

write(Object) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a Java object as a typed bytes sequence.
write(Writable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeArray(ArrayWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeBool(boolean) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a boolean as a typed bytes sequence.
writeBool(boolean, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeBoolean(BooleanWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeBuffer(Buffer, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeByte(byte) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a byte as a typed bytes sequence.
writeByte(byte, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeByte(ByteWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeBytes(byte[], int, int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence, using a given typecode and length.
writeBytes(byte[], int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence, using a given typecode.
writeBytes(byte[]) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes array as a typed bytes sequence.
writeBytes(Buffer) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a bytes buffer as a typed bytes sequence.
writeBytes(BytesWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeDouble(double) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a double as a typed bytes sequence.
writeDouble(double, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeDouble(DoubleWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeFloat(float) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a float as a typed bytes sequence.
writeFloat(float, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeFloat(FloatWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeInt(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes an integer as a typed bytes sequence.
writeInt(int, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeInt(IntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeKey(K) - Method in class org.apache.hadoop.streaming.io.InputWriter
Writes an input key.
writeKey(Object) - Method in class org.apache.hadoop.streaming.io.KeyOnlyTextInputWriter
 
writeKey(Writable) - Method in class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
writeKey(Object) - Method in class org.apache.hadoop.streaming.io.TextInputWriter
 
writeKey(Object) - Method in class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
writeList(List) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a list as a typed bytes sequence.
writeListFooter() - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a list footer.
writeListHeader() - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a list header.
writeLong(long) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a long as a typed bytes sequence.
writeLong(long, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeLong(LongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeMap(Map) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a map as a typed bytes sequence.
writeMap(MapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeMapHeader(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a map header.
writeRaw(byte[]) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a raw sequence of typed bytes.
writeRaw(byte[], int, int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a raw sequence of typed bytes.
writeRecord(Record) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeSortedMap(SortedMapWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeString(String) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a string as a typed bytes sequence.
writeString(String, String) - Method in class org.apache.hadoop.typedbytes.TypedBytesRecordOutput
 
writeText(Text) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeTypedBytes(TypedBytesWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeUTF8(Object) - Method in class org.apache.hadoop.streaming.io.TextInputWriter
 
writeValue(V) - Method in class org.apache.hadoop.streaming.io.InputWriter
Writes an input value.
writeValue(Object) - Method in class org.apache.hadoop.streaming.io.KeyOnlyTextInputWriter
 
writeValue(Writable) - Method in class org.apache.hadoop.streaming.io.RawBytesInputWriter
 
writeValue(Object) - Method in class org.apache.hadoop.streaming.io.TextInputWriter
 
writeValue(Object) - Method in class org.apache.hadoop.streaming.io.TypedBytesInputWriter
 
writeVector(ArrayList) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a vector as a typed bytes sequence.
writeVectorHeader(int) - Method in class org.apache.hadoop.typedbytes.TypedBytesOutput
Writes a vector header.
writeVInt(VIntWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeVLong(VLongWritable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
writeWritable(Writable) - Method in class org.apache.hadoop.typedbytes.TypedBytesWritableOutput
 
A B C D E F G H I J K L M N O P R S T V W 

Copyright © 2017 Apache Software Foundation. All Rights Reserved.