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

A

abort() - Method in interface org.apache.avro.mapred.tether.InputProtocol
Called to abort the task.
accept(Class<?>) - Method in class org.apache.avro.hadoop.io.AvroSerialization
accept(Class<?>) - Method in class org.apache.avro.mapred.AvroSerialization
 
addInputPath(JobConf, Path, Class<? extends AvroMapper>, Schema) - Static method in class org.apache.avro.mapred.AvroMultipleInputs
Add a Path with a custom Schema and AvroMapper to the list of inputs for the map-reduce job.
addMultiNamedOutput(JobConf, String, Class<? extends OutputFormat>, Schema) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Adds a multi named output for the job.
addNamedOutput(JobConf, String, Class<? extends OutputFormat>, Schema) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Adds a named output for the job.
addNamedOutput(Job, String, Class<? extends OutputFormat>, Schema) - Static method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Adds a named output for the job.
addNamedOutput(Job, String, Class<? extends OutputFormat>, Schema, Schema) - Static method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Adds a named output for the job.
addToConfiguration(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Adds the AvroSerialization scheme to the configuration, so SerializationFactory instances constructed from the given configuration will be aware of it.
append(K, V) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
Appends a record to the SortedKeyValueFile.
AvroAsTextInputFormat - Class in org.apache.avro.mapred
An InputFormat for Avro data files, which converts each datum to string form in the input key.
AvroAsTextInputFormat() - Constructor for class org.apache.avro.mapred.AvroAsTextInputFormat
 
AvroCharSequenceComparator<T> - Class in org.apache.avro.hadoop.util
Compares Avro string data (data with schema "string").
AvroCharSequenceComparator() - Constructor for class org.apache.avro.hadoop.util.AvroCharSequenceComparator
 
AvroCollector<T> - Class in org.apache.avro.mapred
A collector for map and reduce output.
AvroCollector() - Constructor for class org.apache.avro.mapred.AvroCollector
 
AvroDatumConverter<INPUT,OUTPUT> - Class in org.apache.avro.hadoop.io
Converts a Java object into an Avro datum.
AvroDatumConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverter
 
AvroDatumConverterFactory - Class in org.apache.avro.hadoop.io
Constructs converters that turn objects (usually from the output of a MR job) into Avro data that can be serialized.
AvroDatumConverterFactory(Configuration) - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory
Creates a new AvroDatumConverterFactory instance.
AvroDatumConverterFactory.AvroWrapperConverter - Class in org.apache.avro.hadoop.io
Converts AvroWrappers into their wrapped Avro data.
AvroDatumConverterFactory.BooleanWritableConverter - Class in org.apache.avro.hadoop.io
Converts BooleanWritables into Booleans.
AvroDatumConverterFactory.BytesWritableConverter - Class in org.apache.avro.hadoop.io
Converts BytesWritables into ByteBuffers.
AvroDatumConverterFactory.ByteWritableConverter - Class in org.apache.avro.hadoop.io
Converts ByteWritables into GenericFixed of size 1.
AvroDatumConverterFactory.DoubleWritableConverter - Class in org.apache.avro.hadoop.io
Converts DoubleWritables into Doubles.
AvroDatumConverterFactory.FloatWritableConverter - Class in org.apache.avro.hadoop.io
Converts FloatWritables into Floats.
AvroDatumConverterFactory.IntWritableConverter - Class in org.apache.avro.hadoop.io
Converts IntWritables into Ints.
AvroDatumConverterFactory.LongWritableConverter - Class in org.apache.avro.hadoop.io
Converts LongWritables into Longs.
AvroDatumConverterFactory.NullWritableConverter - Class in org.apache.avro.hadoop.io
Converts NullWritables into Nulls.
AvroDatumConverterFactory.TextConverter - Class in org.apache.avro.hadoop.io
Converts Text into CharSequences.
AvroDeserializer<T extends AvroWrapper<D>,D> - Class in org.apache.avro.hadoop.io
Deserializes AvroWrapper objects within Hadoop.
AvroDeserializer(Schema, Schema, ClassLoader) - Constructor for class org.apache.avro.hadoop.io.AvroDeserializer
Constructor.
AvroDeserializer(Schema, Schema, DatumReader<D>) - Constructor for class org.apache.avro.hadoop.io.AvroDeserializer
Constructor.
AvroInputFormat<T> - Class in org.apache.avro.mapred
An InputFormat for Avro data files.
AvroInputFormat() - Constructor for class org.apache.avro.mapred.AvroInputFormat
 
AvroJob - Class in org.apache.avro.mapred
Setters to configure jobs for Avro data.
AvroJob - Class in org.apache.avro.mapreduce
Utility methods for configuring jobs that work with Avro.
AvroKey<T> - Class in org.apache.avro.mapred
The wrapper of keys for jobs configured with AvroJob .
AvroKey() - Constructor for class org.apache.avro.mapred.AvroKey
Wrap null.
AvroKey(T) - Constructor for class org.apache.avro.mapred.AvroKey
Wrap a key.
AvroKeyComparator<T> - Class in org.apache.avro.hadoop.io
The RawComparator used by jobs configured with AvroJob.
AvroKeyComparator() - Constructor for class org.apache.avro.hadoop.io.AvroKeyComparator
 
AvroKeyComparator<T> - Class in org.apache.avro.mapred
The RawComparator used by jobs configured with AvroJob.
AvroKeyComparator() - Constructor for class org.apache.avro.mapred.AvroKeyComparator
 
AvroKeyDeserializer<D> - Class in org.apache.avro.hadoop.io
Deserializes AvroKey objects within Hadoop.
AvroKeyDeserializer(Schema, Schema, ClassLoader) - Constructor for class org.apache.avro.hadoop.io.AvroKeyDeserializer
Constructor.
AvroKeyDeserializer(Schema, Schema, DatumReader<D>) - Constructor for class org.apache.avro.hadoop.io.AvroKeyDeserializer
Constructor.
AvroKeyInputFormat<T> - Class in org.apache.avro.mapreduce
A MapReduce InputFormat that can handle Avro container files.
AvroKeyInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyInputFormat
 
AvroKeyOutputFormat<T> - Class in org.apache.avro.mapreduce
FileOutputFormat for writing Avro container files.
AvroKeyOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat
Constructor.
AvroKeyOutputFormat(AvroKeyOutputFormat.RecordWriterFactory) - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat
Constructor.
AvroKeyOutputFormat.RecordWriterFactory<T> - Class in org.apache.avro.mapreduce
A factory for creating record writers.
AvroKeyRecordReader<T> - Class in org.apache.avro.mapreduce
Reads records from an input split representing a chunk of an Avro container file.
AvroKeyRecordReader(Schema) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordReader
Constructor.
AvroKeyRecordWriter<T> - Class in org.apache.avro.mapreduce
Writes Avro records to an Avro container file output stream.
AvroKeyRecordWriter(Schema, GenericData, CodecFactory, OutputStream, int) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordWriter
Constructor.
AvroKeyRecordWriter(Schema, GenericData, CodecFactory, OutputStream) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordWriter
Constructor.
AvroKeyValue<K,V> - Class in org.apache.avro.hadoop.io
A helper object for working with the Avro generic records that are used to store key/value pairs in an Avro container file.
AvroKeyValue(GenericRecord) - Constructor for class org.apache.avro.hadoop.io.AvroKeyValue
Wraps a GenericRecord that is a key value pair.
AvroKeyValue.Iterator<K,V> - Class in org.apache.avro.hadoop.io
A wrapper for iterators over GenericRecords that are known to be KeyValue records.
AvroKeyValueInputFormat<K,V> - Class in org.apache.avro.mapreduce
A MapReduce InputFormat that reads from Avro container files of key/value generic records.
AvroKeyValueInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyValueInputFormat
 
AvroKeyValueOutputFormat<K,V> - Class in org.apache.avro.mapreduce
FileOutputFormat for writing Avro container files of key/value pairs.
AvroKeyValueOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyValueOutputFormat
 
AvroKeyValueRecordReader<K,V> - Class in org.apache.avro.mapreduce
Reads Avro generic records from an Avro container file, where the records contain two fields: 'key' and 'value'.
AvroKeyValueRecordReader(Schema, Schema) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordReader
Constructor.
AvroKeyValueRecordWriter<K,V> - Class in org.apache.avro.mapreduce
Writes key/value pairs to an Avro container file.
AvroKeyValueRecordWriter(AvroDatumConverter<K, ?>, AvroDatumConverter<V, ?>, GenericData, CodecFactory, OutputStream, int) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
Constructor.
AvroKeyValueRecordWriter(AvroDatumConverter<K, ?>, AvroDatumConverter<V, ?>, GenericData, CodecFactory, OutputStream) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
Constructor.
AvroMapper<IN,OUT> - Class in org.apache.avro.mapred
A mapper for Avro data.
AvroMapper() - Constructor for class org.apache.avro.mapred.AvroMapper
 
AvroMultipleInputs - Class in org.apache.avro.mapred
This class supports Avro-MapReduce jobs that have multiple input paths with a different Schema and AvroMapper for each path.
AvroMultipleInputs() - Constructor for class org.apache.avro.mapred.AvroMultipleInputs
 
AvroMultipleOutputs - Class in org.apache.avro.mapred
The AvroMultipleOutputs class simplifies writing Avro output data to multiple outputs
AvroMultipleOutputs(JobConf) - Constructor for class org.apache.avro.mapred.AvroMultipleOutputs
Creates and initializes multiple named outputs support, it should be instantiated in the Mapper/Reducer configure method.
AvroMultipleOutputs - Class in org.apache.avro.mapreduce
The AvroMultipleOutputs class simplifies writing Avro output data to multiple outputs
AvroMultipleOutputs(TaskInputOutputContext<?, ?, ?, ?>) - Constructor for class org.apache.avro.mapreduce.AvroMultipleOutputs
Creates and initializes multiple outputs support, it should be instantiated in the Mapper/Reducer setup method.
AvroOutputFormat<T> - Class in org.apache.avro.mapred
An OutputFormat for Avro data files.
AvroOutputFormat() - Constructor for class org.apache.avro.mapred.AvroOutputFormat
 
AvroOutputFormatBase<K,V> - Class in org.apache.avro.mapreduce
Abstract base class for output formats that write Avro container files.
AvroOutputFormatBase() - Constructor for class org.apache.avro.mapreduce.AvroOutputFormatBase
 
AvroRecordReader<T> - Class in org.apache.avro.mapred
An RecordReader for Avro data files.
AvroRecordReader(JobConf, FileSplit) - Constructor for class org.apache.avro.mapred.AvroRecordReader
 
AvroRecordReader(FileReader<T>, FileSplit) - Constructor for class org.apache.avro.mapred.AvroRecordReader
 
AvroRecordReaderBase<K,V,T> - Class in org.apache.avro.mapreduce
Abstract base class for RecordReaders that read Avro container files.
AvroRecordReaderBase(Schema) - Constructor for class org.apache.avro.mapreduce.AvroRecordReaderBase
Constructor.
AvroReducer<K,V,OUT> - Class in org.apache.avro.mapred
A reducer for Avro data.
AvroReducer() - Constructor for class org.apache.avro.mapred.AvroReducer
 
AvroSequenceFile - Class in org.apache.avro.hadoop.io
A wrapper around a Hadoop SequenceFile that also supports reading and writing Avro data.
AvroSequenceFile.Reader - Class in org.apache.avro.hadoop.io
A reader for SequenceFiles that may contain Avro data.
AvroSequenceFile.Reader.Options - Class in org.apache.avro.hadoop.io
A helper class to encapsulate the options that can be used to construct a Reader.
AvroSequenceFile.Writer - Class in org.apache.avro.hadoop.io
A writer for an uncompressed SequenceFile that supports Avro data.
AvroSequenceFile.Writer.Options - Class in org.apache.avro.hadoop.io
A helper class to encapsulate the options that can be used to construct a Writer.
AvroSequenceFileInputFormat<K,V> - Class in org.apache.avro.mapreduce
An input format for reading from AvroSequenceFiles (sequence files that support Avro data).
AvroSequenceFileInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroSequenceFileInputFormat
 
AvroSequenceFileInputFormat.AvroSequenceFileRecordReader - Class in org.apache.avro.mapreduce
Reads records from a SequenceFile that supports Avro data.
AvroSequenceFileOutputFormat<K,V> - Class in org.apache.avro.mapreduce
A sequence file output format that knows how to write AvroKeys and AvroValues in addition to Writables.
AvroSequenceFileOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroSequenceFileOutputFormat
 
AvroSequenceFileRecordReader() - Constructor for class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
 
AvroSerialization<T> - Class in org.apache.avro.hadoop.io
The Serialization used by jobs configured with AvroJob.
AvroSerialization() - Constructor for class org.apache.avro.hadoop.io.AvroSerialization
 
AvroSerialization<T> - Class in org.apache.avro.mapred
The Serialization used by jobs configured with AvroJob.
AvroSerialization() - Constructor for class org.apache.avro.mapred.AvroSerialization
 
AvroSerializer<T> - Class in org.apache.avro.hadoop.io
Serializes AvroWrapper objects within Hadoop.
AvroSerializer(Schema) - Constructor for class org.apache.avro.hadoop.io.AvroSerializer
Constructor.
AvroSerializer(Schema, DatumWriter<T>) - Constructor for class org.apache.avro.hadoop.io.AvroSerializer
Constructor.
AvroTextOutputFormat<K,V> - Class in org.apache.avro.mapred
The equivalent of TextOutputFormat for writing to Avro Data Files with a "bytes" schema.
AvroTextOutputFormat() - Constructor for class org.apache.avro.mapred.AvroTextOutputFormat
 
AvroUtf8InputFormat - Class in org.apache.avro.mapred
An InputFormat for text files.
AvroUtf8InputFormat() - Constructor for class org.apache.avro.mapred.AvroUtf8InputFormat
 
AvroValue<T> - Class in org.apache.avro.mapred
The wrapper of values for jobs configured with AvroJob .
AvroValue() - Constructor for class org.apache.avro.mapred.AvroValue
Wrap null.
AvroValue(T) - Constructor for class org.apache.avro.mapred.AvroValue
Wrap a value.
AvroValueDeserializer<D> - Class in org.apache.avro.hadoop.io
Deserializes AvroValue objects within Hadoop.
AvroValueDeserializer(Schema, Schema, ClassLoader) - Constructor for class org.apache.avro.hadoop.io.AvroValueDeserializer
Constructor.
AvroValueDeserializer(Schema, Schema, DatumReader<D>) - Constructor for class org.apache.avro.hadoop.io.AvroValueDeserializer
Constructor.
AvroWrapper<T> - Class in org.apache.avro.mapred
The wrapper of data for jobs configured with AvroJob .
AvroWrapper() - Constructor for class org.apache.avro.mapred.AvroWrapper
Wrap null.
AvroWrapper(T) - Constructor for class org.apache.avro.mapred.AvroWrapper
Wrap a datum.
AvroWrapperConverter(Schema) - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.AvroWrapperConverter
 

B

BINARY_PREFIX - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key prefix for a binary output metadata.
BooleanWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BooleanWritableConverter
Constructor.
BytesWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BytesWritableConverter
Constructor.
ByteWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.ByteWritableConverter
Constructor.

C

close() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
close() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
close() - Method in class org.apache.avro.hadoop.io.AvroDeserializer
close() - Method in class org.apache.avro.hadoop.io.AvroSerializer
close() - Method in class org.apache.avro.mapred.AvroMapper
Subclasses can override this as desired.
close() - Method in class org.apache.avro.mapred.AvroMultipleOutputs
Closes all the opened named outputs.
close() - Method in class org.apache.avro.mapred.AvroRecordReader
 
close() - Method in class org.apache.avro.mapred.AvroReducer
Subclasses can override this as desired.
close() - Method in class org.apache.avro.mapred.FsInput
 
close() - Method in class org.apache.avro.mapred.SequenceFileReader
 
close(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyRecordWriter
close(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
close() - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Closes all the opened outputs.
close() - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
close() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
collect(T) - Method in class org.apache.avro.mapred.AvroCollector
 
collect(String, Reporter, Object) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
Output Collector for the default schema.
collect(String, Reporter, Schema, Object) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
OutputCollector with custom schema.
collect(String, Reporter, Schema, Object, String) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
OutputCollector with custom schema and file name.
CombineAvroKeyValueFileInputFormat<K,V> - Class in org.apache.avro.mapreduce
A combine avro keyvalue file input format that can combine small avro files into mappers.
CombineAvroKeyValueFileInputFormat() - Constructor for class org.apache.avro.mapreduce.CombineAvroKeyValueFileInputFormat
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
compare(AvroKey<T>, AvroKey<T>) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
compare(T, T) - Method in class org.apache.avro.hadoop.util.AvroCharSequenceComparator
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.avro.mapred.AvroKeyComparator
 
compare(AvroWrapper<T>, AvroWrapper<T>) - Method in class org.apache.avro.mapred.AvroKeyComparator
 
compareTo(Pair) - Method in class org.apache.avro.mapred.Pair
 
complete() - Method in interface org.apache.avro.mapred.tether.InputProtocol
Called when a task's input is complete.
complete() - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Called when a task's output has completed without error.
CONF_OUTPUT_CODEC - Static variable in class org.apache.avro.mapreduce.AvroJob
The configuration key for a job's output compression codec.
configure(JobConf) - Method in class org.apache.avro.mapred.AvroMapper
Subclasses can override this as desired.
configure(JobConf) - Method in class org.apache.avro.mapred.AvroReducer
Subclasses can override this as desired.
configure(JobConf) - Method in class org.apache.avro.mapred.AvroUtf8InputFormat
 
configure(TaskType, String, String) - Method in interface org.apache.avro.mapred.tether.InputProtocol
Configure the task.
configure(int) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Configure task.
convert(INPUT) - Method in class org.apache.avro.hadoop.io.AvroDatumConverter
 
convert(AvroWrapper<?>) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.AvroWrapperConverter
convert(BooleanWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BooleanWritableConverter
convert(BytesWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BytesWritableConverter
convert(ByteWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.ByteWritableConverter
convert(DoubleWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.DoubleWritableConverter
convert(FloatWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.FloatWritableConverter
convert(IntWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.IntWritableConverter
convert(LongWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.LongWritableConverter
convert(NullWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.NullWritableConverter
convert(Text) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.TextConverter
count(String, String, long) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Increment a task/job counter.
create(Class<IN>) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory
Creates a converter that turns objects of type inputClass into Avro data.
create(Schema, GenericData, CodecFactory, OutputStream, int) - Method in class org.apache.avro.mapreduce.AvroKeyOutputFormat.RecordWriterFactory
Creates a new record writer instance.
createAvroFileReader(SeekableInput, DatumReader<T>) - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
Creates an Avro container file reader from a seekable input stream.
createAvroWrapper() - Method in class org.apache.avro.hadoop.io.AvroDeserializer
Creates a new empty T (extends AvroWrapper) instance.
createAvroWrapper() - Method in class org.apache.avro.hadoop.io.AvroKeyDeserializer
Creates a new empty AvroKey instance.
createAvroWrapper() - Method in class org.apache.avro.hadoop.io.AvroValueDeserializer
Creates a new empty AvroValue instance.
createDataModel(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Gets an instance of data model implementation, defaulting to ReflectData if not explicitly specified.
createDataModel(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
 
createInputDataModel(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
 
createKey() - Method in class org.apache.avro.mapred.AvroRecordReader
 
createMapOutputDataModel(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyInputFormat
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyValueInputFormat
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.CombineAvroKeyValueFileInputFormat
 
createSeekableInput(Configuration, Path) - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
Creates a seekable input stream to an Avro container file.
createValue() - Method in class org.apache.avro.mapred.AvroRecordReader
 
createWriter(AvroSequenceFile.Writer.Options) - Static method in class org.apache.avro.hadoop.io.AvroSequenceFile
Creates a writer from a set of options.

D

DATA_FILENAME - Static variable in class org.apache.avro.hadoop.file.SortedKeyValueFile
The name of the data file within the SortedKeyValueFile directory.
datum() - Method in class org.apache.avro.mapred.AvroWrapper
Return the wrapped datum.
datum(T) - Method in class org.apache.avro.mapred.AvroWrapper
Set the wrapped datum.
DEFLATE_LEVEL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The configuration key for Avro deflate level.
deserialize(T) - Method in class org.apache.avro.hadoop.io.AvroDeserializer
DoubleWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.DoubleWritableConverter
Constructor.

E

equals(Object) - Method in class org.apache.avro.mapred.AvroWrapper
 
equals(Object) - Method in class org.apache.avro.mapred.Pair
 
EXT - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The file name extension for avro data files.

F

fail(String) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Called by a failing task to abort.
FloatWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.FloatWritableConverter
Constructor.
fromHadoopString(String) - Static method in class org.apache.avro.hadoop.file.HadoopCodecFactory
Maps a hadoop codec name into a CodecFactory.
FsInput - Class in org.apache.avro.mapred
Adapt an FSDataInputStream to SeekableInput.
FsInput(Path, Configuration) - Constructor for class org.apache.avro.mapred.FsInput
Construct given a path and a configuration.
FsInput(Path, FileSystem) - Constructor for class org.apache.avro.mapred.FsInput
Construct given a path and a FileSystem.

G

get(K) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
Gets the first value associated with a given key, or null if it is not found.
get() - Method in class org.apache.avro.hadoop.io.AvroKeyValue
Gets the wrapped key/value GenericRecord.
get(int) - Method in class org.apache.avro.mapred.Pair
 
getAvroCodecName(String) - Static method in class org.apache.avro.hadoop.file.HadoopCodecFactory
 
getAvroFileOutputStream(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroOutputFormatBase
Gets the target output stream where the Avro container file should be written.
getBlockSizeBytes() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the desired size of the file blocks.
getBufferSizeBytes() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the desired size of the buffer used when flushing records to disk.
getClassSchema() - Static method in enum org.apache.avro.mapred.tether.TaskType
 
getCodec() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Return the compression codec.
getCollector(String, Reporter) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
getCollector(String, String, Reporter) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
Gets the output collector for a named output.
getCompressionCodec() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the compression codec.
getCompressionCodec(TaskAttemptContext) - Static method in class org.apache.avro.mapreduce.AvroOutputFormatBase
Gets the configured compression codec from the task context.
getCompressionType() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the type of compression.
getConfiguration() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Gets the configuration.
getConfiguration() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Gets the configuration.
getConfiguration() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Gets the Hadoop configuration.
getConfiguration() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the Hadoop configuration.
getConfigurationWithAvroSerialization() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Gets the Hadoop configuration with Avro serialization registered.
getConfigurationWithAvroSerialization() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the Hadoop configuration with Avro serialization registered.
getCountersEnabled(JobConf) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Returns if the counters for the named outputs are enabled or not.
getCountersEnabled(JobContext) - Static method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Returns if the counters for the named outputs are enabled or not.
getCurrentKey() - Method in class org.apache.avro.mapreduce.AvroKeyRecordReader
getCurrentKey() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordReader
getCurrentKey() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
getCurrentRecord() - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
Gets the current record read from the Avro container file.
getCurrentValue() - Method in class org.apache.avro.mapreduce.AvroKeyRecordReader
getCurrentValue() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordReader
getCurrentValue() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
getDataModel() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Return the data model.
getDataModel() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Return the data model.
getDataModelClass(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Gets the data model class for de/serialization.
getDataModelClass(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
Return the job's data model implementation class.
getDeserializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.hadoop.io.AvroSerialization
Gets an object capable of deserializing the output from a Mapper.
getDeserializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.mapred.AvroSerialization
Returns the specified map output deserializer.
getExecutable(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
Get the URI of the application's executable.
getFileSystem() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Gets the filesystem the SequenceFile should be read rom.
getFileSystem() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the filesystem the SequenceFile should be written to.
getIndexInterval() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Gets the index interval.
getInputKeySchema(Configuration) - Static method in class org.apache.avro.mapreduce.AvroJob
Gets the job input key schema.
getInputPath() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Gets the input path for the sequence file.
getInputSchema(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
Return a job's map input schema.
getInputValueSchema(Configuration) - Static method in class org.apache.avro.mapreduce.AvroJob
Gets the job input value schema.
getKey() - Method in class org.apache.avro.hadoop.io.AvroKeyValue
Read the key.
getKeyClass() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the class of the key records.
getKeyReaderSchema(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Gets the reader schema of the AvroKey datum that is being serialized/deserialized.
getKeySchema() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Gets the reader schema for the key.
getKeySchema() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Gets the key schema.
getKeySchema(Schema) - Static method in class org.apache.avro.mapred.Pair
Return a pair's key schema.
getKeyWriterSchema(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Gets the writer schema of the AvroKey datum that is being serialized/deserialized.
getMapOutputKeySchema(Configuration) - Static method in class org.apache.avro.mapreduce.AvroJob
Gets the map output key schema.
getMapOutputSchema(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
Return a job's map output key schema.
getMapOutputValueSchema(Configuration) - Static method in class org.apache.avro.mapreduce.AvroJob
Gets the map output value schema.
getMetadata() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the SequenceFile metadata to store in the header.
getNamedOutputFormatClass(JobConf, String) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Returns the named output OutputFormat.
getNamedOutputs() - Method in class org.apache.avro.mapred.AvroMultipleOutputs
Returns iterator with the defined name outputs.
getNamedOutputsList(JobConf) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Returns list of channel names.
getOutputCompressionType(Configuration) - Static method in class org.apache.avro.mapreduce.AvroSequenceFileOutputFormat
Gets type of compression for the output sequence file.
getOutputKeySchema(Configuration) - Static method in class org.apache.avro.mapreduce.AvroJob
Gets the job output key schema.
getOutputPath() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the output path for the sequence file.
getOutputSchema(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
Return a job's output key schema.
getOutputValueSchema(Configuration) - Static method in class org.apache.avro.mapreduce.AvroJob
Gets the job output value schema.
getPairSchema(Schema, Schema) - Static method in class org.apache.avro.mapred.Pair
Get a pair schema.
getPath() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Gets the input path.
getPath() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Gets the output path.
getPos() - Method in class org.apache.avro.mapred.AvroRecordReader
 
getProgress() - Method in class org.apache.avro.mapred.AvroRecordReader
 
getProgress() - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
getProgress() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
getProgressable() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the object to report progress to.
getProtocol(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
Extract from the job configuration file an instance of the TRANSPROTO enumeration to represent the protocol to use for the communication
getReaderSchema() - Method in class org.apache.avro.hadoop.io.AvroDeserializer
Gets the reader schema used for deserializing.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.AvroAsTextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.AvroInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.AvroUtf8InputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.SequenceFileInputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.avro.mapred.AvroOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.avro.mapred.AvroTextOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyOutputFormat
getRecordWriter(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyValueOutputFormat
getRecordWriter(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroSequenceFileOutputFormat
getReplicationFactor() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the desired number of replicas to store for each block of the file.
getSchema(Schema, Schema) - Static method in class org.apache.avro.hadoop.io.AvroKeyValue
Creates a KeyValuePair generic record schema.
getSchema() - Method in class org.apache.avro.mapred.Pair
 
getSchema() - Method in class org.apache.avro.mapred.SequenceFileReader
 
getSchema() - Method in enum org.apache.avro.mapred.tether.TaskType
 
getSerializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.hadoop.io.AvroSerialization
Gets an object capable of serializing output from a Mapper.
getSerializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.mapred.AvroSerialization
Returns the specified output serializer.
getSyncInterval(TaskAttemptContext) - Static method in class org.apache.avro.mapreduce.AvroOutputFormatBase
Gets the configured sync interval from the task context.
getValue() - Method in class org.apache.avro.hadoop.io.AvroKeyValue
Read the value.
getValueClass() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the class of the value records.
getValueReaderSchema(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Gets the reader schema of the AvroValue datum that is being serialized/deserialized.
getValueSchema() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Gets the reader schema for the value.
getValueSchema() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Gets the value schema.
getValueSchema(Schema) - Static method in class org.apache.avro.mapred.Pair
Return a pair's value schema.
getValueWriterSchema(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Gets the writer schema of the AvroValue datum that is being serialized/deserialized.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.AvroWrapperConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BooleanWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BytesWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.ByteWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.DoubleWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.FloatWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.IntWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.LongWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.NullWritableConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.TextConverter
Gets the writer schema that should be used to serialize the output Avro datum.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroDeserializer
Gets the writer schema used for deserializing.
getWriterSchema() - Method in class org.apache.avro.hadoop.io.AvroSerializer
Gets the writer schema being used for serialization.
getWriterSchema() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
Gets the writer schema for the key/value pair generic record.

H

HadoopCodecFactory - Class in org.apache.avro.hadoop.file
Encapsulates the ability to specify and configure an avro compression codec from a given hadoop codec defined with the configuration parameter: mapred.output.compression.codec Currently there are three codecs registered by default: org.apache.hadoop.io.compress.DeflateCodec will map to deflate org.apache.hadoop.io.compress.SnappyCodec will map to snappy org.apache.hadoop.io.compress.BZip2Codec will map to zbip2 org.apache.hadoop.io.compress.GZipCodec will map to deflate
HadoopCodecFactory() - Constructor for class org.apache.avro.hadoop.file.HadoopCodecFactory
 
hashCode() - Method in class org.apache.avro.mapred.AvroWrapper
 
hashCode() - Method in class org.apache.avro.mapred.Pair
 
hasNext() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
hasNext() - Method in class org.apache.avro.mapred.SequenceFileReader
 

I

IGNORE_FILES_WITHOUT_EXTENSION_KEY - Static variable in class org.apache.avro.mapred.AvroInputFormat
Whether to silently ignore input files without the .avro extension
IGNORE_INPUTS_WITHOUT_EXTENSION_DEFAULT - Static variable in class org.apache.avro.mapred.AvroInputFormat
Default of whether to silently ignore input files without the .avro extension.
INDEX_FILENAME - Static variable in class org.apache.avro.hadoop.file.SortedKeyValueFile
The name of the index file within the SortedKeyValueFile directory.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
input(ByteBuffer, long) - Method in interface org.apache.avro.mapred.tether.InputProtocol
Send a block of input data to a task.
INPUT_IS_REFLECT - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key for reflection-based input representation.
INPUT_SCHEMA - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key for a job's input schema.
InputProtocol - Interface in org.apache.avro.mapred.tether
Transmit inputs to a map or reduce task sub-process.
InputProtocol.Callback - Interface in org.apache.avro.mapred.tether
Transmit inputs to a map or reduce task sub-process.
INSTANCE - Static variable in class org.apache.avro.hadoop.util.AvroCharSequenceComparator
A singleton instance.
IntWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.IntWritableConverter
Constructor.
isMultiNamedOutput(JobConf, String) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Returns if a named output is multiple.
isSplitable(FileSystem, Path) - Method in class org.apache.avro.mapred.AvroUtf8InputFormat
 
iterator() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
Returns an iterator starting at the current position in the file.
Iterator(Iterator<? extends GenericRecord>) - Constructor for class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
Constructs an iterator over key-value map entries out of a generic iterator.
iterator() - Method in class org.apache.avro.mapred.SequenceFileReader
 

K

key() - Method in class org.apache.avro.mapred.Pair
Get the key.
key(K) - Method in class org.apache.avro.mapred.Pair
Set the key.
KEY_FIELD - Static variable in class org.apache.avro.hadoop.io.AvroKeyValue
The name of the generic record field containing the key.
KEY_VALUE_PAIR_RECORD_NAME - Static variable in class org.apache.avro.hadoop.io.AvroKeyValue
The name of the key value pair generic record.
KEY_VALUE_PAIR_RECORD_NAMESPACE - Static variable in class org.apache.avro.hadoop.io.AvroKeyValue
The namespace of the key value pair generic record.

L

length() - Method in class org.apache.avro.mapred.FsInput
 
listStatus(JobConf) - Method in class org.apache.avro.mapred.AvroAsTextInputFormat
 
listStatus(JobConf) - Method in class org.apache.avro.mapred.AvroInputFormat
 
LongWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.LongWritableConverter
Constructor.

M

map(IN, AvroCollector<OUT>, Reporter) - Method in class org.apache.avro.mapred.AvroMapper
Called with each map input datum.
MAP_OUTPUT_IS_REFLECT - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key for reflection-based map output representation.
MAP_OUTPUT_SCHEMA - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key for a job's intermediate schema.
METADATA_FIELD_KEY_SCHEMA - Static variable in class org.apache.avro.hadoop.io.AvroSequenceFile
The SequenceFile.Metadata field for the Avro key writer schema.
METADATA_FIELD_VALUE_SCHEMA - Static variable in class org.apache.avro.hadoop.io.AvroSequenceFile
The SequenceFile.Metadata field for the Avro value writer schema.

N

next() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
next(AvroWrapper<T>, NullWritable) - Method in class org.apache.avro.mapred.AvroRecordReader
 
next() - Method in class org.apache.avro.mapred.SequenceFileReader
 
next(Pair<K, V>) - Method in class org.apache.avro.mapred.SequenceFileReader
 
nextKeyValue() - Method in class org.apache.avro.mapreduce.AvroKeyRecordReader
nextKeyValue() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordReader
nextKeyValue() - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
nextKeyValue() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
NullWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.NullWritableConverter
Constructor.

O

open(InputStream) - Method in class org.apache.avro.hadoop.io.AvroDeserializer
open(OutputStream) - Method in class org.apache.avro.hadoop.io.AvroSerializer
Options() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
 
Options() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
 
Options() - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
 
Options() - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Creates a new Options instance with default values.
org.apache.avro.hadoop.file - package org.apache.avro.hadoop.file
 
org.apache.avro.hadoop.io - package org.apache.avro.hadoop.io
 
org.apache.avro.hadoop.util - package org.apache.avro.hadoop.util
 
org.apache.avro.mapred - package org.apache.avro.mapred
Run Hadoop MapReduce jobs over Avro data, with map and reduce functions written in Java.
org.apache.avro.mapred.tether - package org.apache.avro.mapred.tether
Run Hadoop MapReduce jobs over Avro data, with map and reduce functions run in a sub-process.
org.apache.avro.mapreduce - package org.apache.avro.mapreduce
 
output(ByteBuffer) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Send an output datum.
OUTPUT_CODEC - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key for a job's output compression codec.
OUTPUT_SCHEMA - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key for a job's output schema.
outputPartitioned(int, ByteBuffer) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Send map output datum explicitly naming its partition.
OutputProtocol - Interface in org.apache.avro.mapred.tether
Transmit outputs from a map or reduce task to parent.
OutputProtocol.Callback - Interface in org.apache.avro.mapred.tether
Transmit outputs from a map or reduce task to parent.

P

Pair<K,V> - Class in org.apache.avro.mapred
A key/value pair.
Pair(Schema) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(K, Schema, V, Schema) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Object, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(GenericContainer, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(CharSequence, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(ByteBuffer, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Integer, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Long, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Float, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Double, Void) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, Object) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, Integer) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, Long) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, Float) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, Double) - Constructor for class org.apache.avro.mapred.Pair
 
Pair(Void, Void) - Constructor for class org.apache.avro.mapred.Pair
 
partitions(int) - Method in interface org.apache.avro.mapred.tether.InputProtocol
Set the number of map output partitions.
pastSync(long) - Method in class org.apache.avro.mapred.SequenceFileReader
 
PROTOCOL - Static variable in interface org.apache.avro.mapred.tether.InputProtocol.Callback
 
PROTOCOL - Static variable in interface org.apache.avro.mapred.tether.InputProtocol
 
PROTOCOL - Static variable in interface org.apache.avro.mapred.tether.OutputProtocol.Callback
 
PROTOCOL - Static variable in interface org.apache.avro.mapred.tether.OutputProtocol
 
put(int, Object) - Method in class org.apache.avro.mapred.Pair
 

R

read(byte[], int, int) - Method in class org.apache.avro.mapred.FsInput
 
Reader(SortedKeyValueFile.Reader.Options) - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
Constructs a reader.
Reader(AvroSequenceFile.Reader.Options) - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Reader
Creates a new Reader from a SequenceFile that supports Avro data.
RecordWriterFactory() - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat.RecordWriterFactory
 
reduce(K, Iterable<V>, AvroCollector<OUT>, Reporter) - Method in class org.apache.avro.mapred.AvroReducer
Called with all map output values with a given key.
remove() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
remove() - Method in class org.apache.avro.mapred.SequenceFileReader
 
runJob(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
Submit a job to the map/reduce cluster.

S

SCHEMA$ - Static variable in enum org.apache.avro.mapred.tether.TaskType
 
seek(long) - Method in class org.apache.avro.mapred.FsInput
 
SequenceFileInputFormat<K,V> - Class in org.apache.avro.mapred
An InputFormat for sequence files.
SequenceFileInputFormat() - Constructor for class org.apache.avro.mapred.SequenceFileInputFormat
 
SequenceFileReader<K,V> - Class in org.apache.avro.mapred
A FileReader for sequence files.
SequenceFileReader(File) - Constructor for class org.apache.avro.mapred.SequenceFileReader
 
SequenceFileReader(URI, Configuration) - Constructor for class org.apache.avro.mapred.SequenceFileReader
 
SequenceFileReader(SequenceFile.Reader, Configuration) - Constructor for class org.apache.avro.mapred.SequenceFileReader
 
SequenceFileRecordReader<K,V> - Class in org.apache.avro.mapred
A RecordReader for sequence files.
SequenceFileRecordReader(JobConf, FileSplit) - Constructor for class org.apache.avro.mapred.SequenceFileRecordReader
 
serialize(AvroWrapper<T>) - Method in class org.apache.avro.hadoop.io.AvroSerializer
set(K, V) - Method in class org.apache.avro.mapred.Pair
Set both the key and value.
setCombinerClass(JobConf, Class<? extends AvroReducer>) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's combiner implementation.
setConf(Configuration) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
setConf(Configuration) - Method in class org.apache.avro.mapred.AvroKeyComparator
 
setCountersEnabled(JobConf, boolean) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Enables or disables counters for the named outputs.
setCountersEnabled(Job, boolean) - Static method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Enables or disables counters for the named outputs.
setDataModelClass(Configuration, Class<? extends GenericData>) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Sets the data model class for de/serialization.
setDataModelClass(JobConf, Class<? extends GenericData>) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's data model implementation class.
setDataModelClass(Job, Class<? extends GenericData>) - Static method in class org.apache.avro.mapreduce.AvroJob
Sets the job data model class.
setDeflateLevel(JobConf, int) - Static method in class org.apache.avro.mapred.AvroOutputFormat
Enable output compression using the deflate codec and specify its level.
setExecutable(JobConf, File) - Static method in class org.apache.avro.mapred.tether.TetherJob
Set the URI for the application's executable.
setExecutable(JobConf, File, List<String>, boolean) - Static method in class org.apache.avro.mapred.tether.TetherJob
Set the URI for the application's executable (i.e the program to run in a subprocess and provides the mapper/reducer).
setInputKeySchema(Job, Schema) - Static method in class org.apache.avro.mapreduce.AvroJob
Sets the job input key schema.
setInputReflect(JobConf) - Static method in class org.apache.avro.mapred.AvroJob
Indicate that a job's input data should use reflect representation.
setInputSchema(JobConf, Schema) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's map input schema.
setInputSequenceFile(JobConf) - Static method in class org.apache.avro.mapred.AvroJob
Indicate that a job's input files are in SequenceFile format.
setInputValueSchema(Job, Schema) - Static method in class org.apache.avro.mapreduce.AvroJob
Sets the job input value schema.
setKey(K) - Method in class org.apache.avro.hadoop.io.AvroKeyValue
Sets the key.
setKeyReaderSchema(Configuration, Schema) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Sets the reader schema of the AvroKey datum that is being serialized/deserialized.
setKeyWriterSchema(Configuration, Schema) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Sets the writer schema of the AvroKey datum that is being serialized/deserialized.
setMapOutputKeySchema(Job, Schema) - Static method in class org.apache.avro.mapreduce.AvroJob
Sets the map output key schema.
setMapOutputReflect(JobConf) - Static method in class org.apache.avro.mapred.AvroJob
Indicate that a job's map output data should use reflect representation.
setMapOutputSchema(JobConf, Schema) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's map output schema.
setMapOutputValueSchema(Job, Schema) - Static method in class org.apache.avro.mapreduce.AvroJob
Sets the map output value schema.
setMapperClass(JobConf, Class<? extends AvroMapper>) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's mapper implementation.
setOutputCodec(JobConf, String) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's output compression codec.
setOutputCompressionType(Job, SequenceFile.CompressionType) - Static method in class org.apache.avro.mapreduce.AvroSequenceFileOutputFormat
Sets the type of compression for the output sequence file.
setOutputKeySchema(Job, Schema) - Static method in class org.apache.avro.mapreduce.AvroJob
Sets the job output key schema.
setOutputMeta(JobConf, String, String) - Static method in class org.apache.avro.mapred.AvroJob
Add metadata to job output files.
setOutputMeta(JobConf, String, long) - Static method in class org.apache.avro.mapred.AvroJob
Add metadata to job output files.
setOutputMeta(JobConf, String, byte[]) - Static method in class org.apache.avro.mapred.AvroJob
Add metadata to job output files.
setOutputSchema(JobConf, Schema) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's output schema.
setOutputValueSchema(Job, Schema) - Static method in class org.apache.avro.mapreduce.AvroJob
Sets the job output value schema.
setProtocol(JobConf, String) - Static method in class org.apache.avro.mapred.tether.TetherJob
Determines which transport protocol (e.g http or sasl) used to communicate between the parent and subprocess
setReducerClass(JobConf, Class<? extends AvroReducer>) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's reducer implementation.
setReflect(JobConf) - Static method in class org.apache.avro.mapred.AvroJob
Indicate that all a job's data should use the reflect representation.
setSyncInterval(JobConf, int) - Static method in class org.apache.avro.mapred.AvroOutputFormat
Set the sync interval to be used by the underlying DataFileWriter.
setValue(V) - Method in class org.apache.avro.hadoop.io.AvroKeyValue
Sets the value.
setValueReaderSchema(Configuration, Schema) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Sets the reader schema of the AvroValue datum that is being serialized/deserialized.
setValueWriterSchema(Configuration, Schema) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Sets the writer schema of the AvroValue datum that is being serialized/deserialized.
SortedKeyValueFile - Class in org.apache.avro.hadoop.file
A SortedKeyValueFile is an indexed Avro container file of KeyValue records sorted by key.
SortedKeyValueFile() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile
 
SortedKeyValueFile.Reader<K,V> - Class in org.apache.avro.hadoop.file
Reads a SortedKeyValueFile by loading the key index into memory.
SortedKeyValueFile.Reader.Options - Class in org.apache.avro.hadoop.file
A class to encapsulate the options of a Reader.
SortedKeyValueFile.Writer<K,V> - Class in org.apache.avro.hadoop.file
Writes a SortedKeyValueFile.
SortedKeyValueFile.Writer.Options - Class in org.apache.avro.hadoop.file
A class to encapsulate the various options of a SortedKeyValueFile.Writer.
status(String) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Update the task's status message.
submitJob(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
Submit a job to the Map-Reduce framework.
sync(long) - Method in class org.apache.avro.mapred.SequenceFileReader
 
sync() - Method in class org.apache.avro.mapreduce.AvroKeyRecordWriter
Return the current position as a value that may be passed to DataFileReader.seek(long).
sync() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
Return the current position as a value that may be passed to DataFileReader.seek(long).
sync(String, String) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Gets the record writer from job's output format.
sync() - Method in interface org.apache.avro.mapreduce.Syncable
Return the current position as a value that may be passed to DataFileReader.seek(long).
SYNC_INTERVAL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The configuration key for Avro sync interval.
Syncable - Interface in org.apache.avro.mapreduce
 

T

TaskType - Enum in org.apache.avro.mapred.tether
 
tell() - Method in class org.apache.avro.mapred.FsInput
 
tell() - Method in class org.apache.avro.mapred.SequenceFileReader
 
TETHER_EXEC - Static variable in class org.apache.avro.mapred.tether.TetherJob
 
TETHER_EXEC_ARGS - Static variable in class org.apache.avro.mapred.tether.TetherJob
 
TETHER_EXEC_CACHED - Static variable in class org.apache.avro.mapred.tether.TetherJob
 
TETHER_PROTOCOL - Static variable in class org.apache.avro.mapred.tether.TetherJob
 
TetherJob - Class in org.apache.avro.mapred.tether
Constructs and submits tether jobs.
TetherJob() - Constructor for class org.apache.avro.mapred.tether.TetherJob
 
TEXT_PREFIX - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key prefix for a text output metadata.
TextConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.TextConverter
Constructor.
toString() - Method in class org.apache.avro.mapred.AvroWrapper
Get the wrapped datum as JSON.
toString() - Method in class org.apache.avro.mapred.Pair
 

V

value() - Method in class org.apache.avro.mapred.Pair
Get the value.
value(V) - Method in class org.apache.avro.mapred.Pair
Set the value.
VALUE_FIELD - Static variable in class org.apache.avro.hadoop.io.AvroKeyValue
The name of the generic record field containing the value.
valueOf(String) - Static method in enum org.apache.avro.mapred.tether.TaskType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.avro.mapred.tether.TaskType
Returns an array containing the constants of this enum type, in the order they are declared.

W

withBlockSizeBytes(long) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the desired size of the file blocks.
withBufferSizeBytes(int) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the write buffer size in bytes.
withCodec(String) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Set the compression codec.
withCodec(CodecFactory) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Set the compression codec.
withCompressionCodec(CompressionCodec) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the compression codec to use if it is enabled.
withCompressionType(SequenceFile.CompressionType) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the type of compression.
withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Sets the configuration.
withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Sets the configuration.
withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Sets the Hadoop configuration.
withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the Hadoop configuration.
withDataModel(GenericData) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Set the data model.
withDataModel(GenericData) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Set the data model.
withFileSystem(FileSystem) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Sets the filesystem the SequenceFile should be read from.
withFileSystem(FileSystem) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the filesystem the SequenceFile should be written to.
withIndexInterval(int) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Sets the index interval.
withInputPath(Path) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Sets the input path for the SequenceFile.
withKeyClass(Class<?>) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the class of the key records to be written.
withKeySchema(Schema) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Sets the reader schema for the key.
withKeySchema(Schema) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Sets the key schema.
withKeySchema(Schema) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Sets the reader schema of the key records when using Avro data.
withKeySchema(Schema) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the writer schema of the key records when using Avro data.
withMetadata(SequenceFile.Metadata) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the metadata that should be stored in the file header.
withOutputPath(Path) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the output path for the SequenceFile.
withPath(Path) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Sets the input path.
withPath(Path) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Sets the output path.
withProgressable(Progressable) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets an object to report progress to.
withReplicationFactor(short) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the desired replication factor for the file.
withValueClass(Class<?>) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the class of the value records to be written.
withValueSchema(Schema) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
Sets the reader schema for the value.
withValueSchema(Schema) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Sets the value schema.
withValueSchema(Schema) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
Sets the reader schema of the value records when using Avro data.
withValueSchema(Schema) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Sets the writer schema of the value records when using Avro data.
write(AvroKey<T>, NullWritable) - Method in class org.apache.avro.mapreduce.AvroKeyRecordWriter
write(K, V) - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
write(String, Object) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Write key and value to the namedOutput.
write(String, Object, Object) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Write key and value to the namedOutput.
write(String, Object, Object, String) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Write key and value to baseOutputPath using the namedOutput.
write(Object, Object, String) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Write key value to an output file name.
write(Object, Object, Schema, Schema, String) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
Write key value to an output file name.
Writer(SortedKeyValueFile.Writer.Options) - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
Creates a writer for a new file.
Writer(AvroSequenceFile.Writer.Options) - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Writer
Creates a new Writer to a SequenceFile that supports Avro data.

X

XZ_LEVEL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The configuration key for Avro XZ level.

Z

ZSTD_BUFFERPOOL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The configuration key for Avro ZSTD buffer pool.
ZSTD_LEVEL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The configuration key for Avro ZSTD level.
A B C D E F G H I K L M N O P R S T V W X Z 
Skip navigation links

Copyright © 2009–2023 The Apache Software Foundation. All rights reserved.