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

A

abort() - Method in interface org.apache.avro.mapred.tether.InputProtocol
Called to abort the task.
AbstractAvroMojo - Class in org.apache.avro.mojo
Base for Avro Compiler Mojos.
AbstractAvroMojo() - Constructor for class org.apache.avro.mojo.AbstractAvroMojo
 
accept(Class<?>) - Method in class org.apache.avro.hadoop.io.AvroSerialization
accept(Class<?>) - Method in class org.apache.avro.mapred.AvroSerialization
 
add(T) - Method in class org.apache.avro.generic.GenericData.Array
 
add(int, T) - Method in class org.apache.avro.generic.GenericData.Array
 
addAlias(String) - Method in class org.apache.avro.Schema
If this is a record, enum or fixed, add an alias.
addAlias(String, String) - Method in class org.apache.avro.Schema
If this is a record, enum or fixed, add an alias.
addAlias(String) - Method in class org.apache.avro.Schema.Field
 
addCodec(String, CodecFactory) - Static method in class org.apache.avro.file.CodecFactory
Adds a new codec implementation.
addConnector(Connector) - Method in class org.apache.avro.ipc.HttpServer
 
addEscapes(String) - Static method in error org.apache.avro.compiler.idl.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addFileset(FileSet) - Method in class org.apache.avro.compiler.specific.ProtocolTask
Add a fileset.
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.
addProp(String, String) - Method in class org.apache.avro.JsonProperties
Adds a property with the given name name and value value.
addProp(String, JsonNode) - Method in class org.apache.avro.JsonProperties
Adds a property with the given name name and value value.
addProp(String, JsonNode) - Method in class org.apache.avro.Schema
 
addRPCPlugin(RPCPlugin) - Method in class org.apache.avro.ipc.Requestor
Adds a new plugin to manipulate RPC metadata.
addRPCPlugin(RPCPlugin) - Method in class org.apache.avro.ipc.Responder
Adds a new plugin to manipulate per-call metadata.
addSpan(Span) - Method in class org.apache.avro.ipc.trace.FileSpanStorage
 
addSpan(Span) - Method in class org.apache.avro.ipc.trace.InMemorySpanStorage
 
addSpan(Span) - Method in interface org.apache.avro.ipc.trace.SpanStorage
Add a span.
addStringable(Class) - Method in class org.apache.avro.reflect.ReflectData
Cause a class to be treated as though it had an Stringable annotation.
addToArray(Object, long, Object) - Method in class org.apache.avro.generic.GenericDatumReader
addToArray(Object, long, Object) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
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.
addToMap(Object, Object, Object) - Method in class org.apache.avro.generic.GenericDatumReader
addTrace(Trace) - Method in class org.apache.avro.ipc.trace.TraceCollection
Add a trace to this collection.
addTypes(Map<String, Schema>) - Method in class org.apache.avro.Schema.Parser
Adds the provided types to the set of defined, named types known to this parser.
adjustBeginLineColumn(int, int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Method to adjust line and column numbers for the start of a token.
AdjustBuffSize() - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
adjustments - Variable in class org.apache.avro.io.parsing.Symbol.EnumAdjustAction
 
advance(Symbol) - Method in class org.apache.avro.io.parsing.Parser
Recursively replaces the symbol at the top of the stack with its production, until the top is a terminal.
aliases() - Method in class org.apache.avro.Schema.Field
Return the defined aliases as an unmodifieable Set.
aliases(String...) - Method in class org.apache.avro.SchemaBuilder.NamedBuilder
configure this type's optional name aliases
and() - Method in class org.apache.avro.SchemaBuilder.UnionAccumulator
Add an additional type to this union
AnyIdentifier() - Method in class org.apache.avro.compiler.idl.Idl
 
append(D) - Method in class org.apache.avro.file.DataFileWriter
Append a datum to the file.
append(K, V) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
Appends a record to the SortedKeyValueFile.
append(List<ByteBuffer>) - Method in class org.apache.avro.util.ByteBufferOutputStream
Append a list of ByteBuffers to this stream.
appendAllFrom(DataFileStream<D>, boolean) - Method in class org.apache.avro.file.DataFileWriter
Appends data from another file.
appendEncoded(ByteBuffer) - Method in class org.apache.avro.file.DataFileWriter
Expert: Append a pre-encoded datum to the file.
appendTo(File) - Method in class org.apache.avro.file.DataFileWriter
Open a writer appending to an existing file.
appendTo(SeekableInput, OutputStream) - Method in class org.apache.avro.file.DataFileWriter
Open a writer appending to an existing file.
applyAliases(Schema, Schema) - Static method in class org.apache.avro.Schema
Rewrite a writer's schema using the aliases from a reader's schema.
ARRAY - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
array() - Static method in class org.apache.avro.SchemaBuilder
Create a builder for an Avro array This is equivalent to:
array() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build an Avro array type
array() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build an Avro array type Example usage:
array() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build an Avro array type
ARRAY_END - Static variable in class org.apache.avro.io.parsing.Symbol
 
ARRAY_START - Static variable in class org.apache.avro.io.parsing.Symbol
 
arrayDefault(List<V>) - Method in class org.apache.avro.SchemaBuilder.ArrayDefault
Completes this field with the default value provided, cannot be null
arrayNext() - Method in class org.apache.avro.io.BinaryDecoder
 
arrayNext() - Method in class org.apache.avro.io.Decoder
Processes the next block of an array and returns the number of items in the block and let's the caller read those items.
arrayNext() - Method in class org.apache.avro.io.JsonDecoder
 
arrayNext() - Method in class org.apache.avro.io.ValidatingDecoder
 
ArrayType() - Method in class org.apache.avro.compiler.idl.Idl
 
AT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
AvroAlias - Annotation Type in org.apache.avro.reflect
Adds the given name and space as an alias to the schema.
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
 
AvroColumnReader<D> - Class in org.apache.trevni.avro
Read files written with AvroColumnWriter.
AvroColumnReader(AvroColumnReader.Params) - Constructor for class org.apache.trevni.avro.AvroColumnReader
Construct a reader for a file.
AvroColumnReader.Params - Class in org.apache.trevni.avro
Parameters for reading an Avro column file.
AvroColumnReader.Params(File) - Constructor for class org.apache.trevni.avro.AvroColumnReader.Params
Construct reading from a file.
AvroColumnReader.Params(Input) - Constructor for class org.apache.trevni.avro.AvroColumnReader.Params
Construct reading from input.
AvroColumnWriter<D> - Class in org.apache.trevni.avro
Write Avro records to a Trevni column file.
AvroColumnWriter(Schema, ColumnFileMetaData) - Constructor for class org.apache.trevni.avro.AvroColumnWriter
 
AvroColumnWriter(Schema, ColumnFileMetaData, GenericData) - Constructor for class org.apache.trevni.avro.AvroColumnWriter
 
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.AvroWrapperConverter(Schema) - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.AvroWrapperConverter
 
AvroDatumConverterFactory.BooleanWritableConverter - Class in org.apache.avro.hadoop.io
Converts BooleanWritables into Booleans.
AvroDatumConverterFactory.BooleanWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BooleanWritableConverter
Constructor.
AvroDatumConverterFactory.BytesWritableConverter - Class in org.apache.avro.hadoop.io
Converts BytesWritables into ByteBuffers.
AvroDatumConverterFactory.BytesWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BytesWritableConverter
Constructor.
AvroDatumConverterFactory.ByteWritableConverter - Class in org.apache.avro.hadoop.io
Converts ByteWritables into GenericFixed of size 1.
AvroDatumConverterFactory.ByteWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.ByteWritableConverter
Constructor.
AvroDatumConverterFactory.DoubleWritableConverter - Class in org.apache.avro.hadoop.io
Converts DoubleWritables into Doubles.
AvroDatumConverterFactory.DoubleWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.DoubleWritableConverter
Constructor.
AvroDatumConverterFactory.FloatWritableConverter - Class in org.apache.avro.hadoop.io
Converts FloatWritables into Floats.
AvroDatumConverterFactory.FloatWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.FloatWritableConverter
Constructor.
AvroDatumConverterFactory.IntWritableConverter - Class in org.apache.avro.hadoop.io
Converts IntWritables into Ints.
AvroDatumConverterFactory.IntWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.IntWritableConverter
Constructor.
AvroDatumConverterFactory.LongWritableConverter - Class in org.apache.avro.hadoop.io
Converts LongWritables into Longs.
AvroDatumConverterFactory.LongWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.LongWritableConverter
Constructor.
AvroDatumConverterFactory.NullWritableConverter - Class in org.apache.avro.hadoop.io
Converts NullWritables into Nulls.
AvroDatumConverterFactory.NullWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.NullWritableConverter
Constructor.
AvroDatumConverterFactory.TextConverter - Class in org.apache.avro.hadoop.io
Converts Text into CharSequences.
AvroDatumConverterFactory.TextConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.TextConverter
Constructor.
AvroDefault - Annotation Type in org.apache.avro.reflect
Specifies a default value for a field as a JSON string.
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.
AvroEncode - Annotation Type in org.apache.avro.reflect
Expert: Fields with this annotation are encoded using the given custom encoder.
AvroGenerated - Annotation Type in org.apache.avro.specific
Indicates that an annotated class is an Avro generated class.
AvroIgnore - Annotation Type in org.apache.avro.reflect
Marks a field as transient.
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.
AvroKeyOutputFormat.RecordWriterFactory() - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat.RecordWriterFactory
 
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.
AvroKeyValue.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.
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
 
AvroMeta - Annotation Type in org.apache.avro.reflect
Adds the given key:Value pair as metadata into the schema, at the corresponding node.
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.
AvroName - Annotation Type in org.apache.avro.reflect
Sets the avroname for this java field.
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
 
AvroRemoteException - Exception in org.apache.avro
Base class for exceptions thrown to client by server.
AvroRemoteException() - Constructor for exception org.apache.avro.AvroRemoteException
 
AvroRemoteException(Throwable) - Constructor for exception org.apache.avro.AvroRemoteException
 
AvroRemoteException(Object) - Constructor for exception org.apache.avro.AvroRemoteException
 
AvroRemoteException(Object, Throwable) - Constructor for exception org.apache.avro.AvroRemoteException
 
AvroRuntimeException - Exception in org.apache.avro
Base Avro exception.
AvroRuntimeException(Throwable) - Constructor for exception org.apache.avro.AvroRuntimeException
 
AvroRuntimeException(String) - Constructor for exception org.apache.avro.AvroRuntimeException
 
AvroRuntimeException(String, Throwable) - Constructor for exception org.apache.avro.AvroRuntimeException
 
AvroSchema - Annotation Type in org.apache.avro.reflect
Declares that a Java type should have a specified Avro schema, overriding the normally inferred schema.
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(AvroSequenceFile.Reader.Options) - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Reader
Creates a new Reader from a SequenceFile that supports 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.Reader.Options() - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
 
AvroSequenceFile.Writer - Class in org.apache.avro.hadoop.io
A writer for an uncompressed SequenceFile that supports Avro data.
AvroSequenceFile.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.
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.
AvroSequenceFile.Writer.Options() - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Creates a new Options instance with default values.
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.
AvroSequenceFileInputFormat.AvroSequenceFileRecordReader() - Constructor for class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
 
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
 
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
 
AvroTrace - Interface in org.apache.avro.ipc.trace
 
AvroTrace.Callback - Interface in org.apache.avro.ipc.trace
 
AvroTrevniInputFormat<T> - Class in org.apache.trevni.avro
An InputFormat for Trevni files.
AvroTrevniInputFormat() - Constructor for class org.apache.trevni.avro.AvroTrevniInputFormat
 
AvroTrevniKeyInputFormat<T> - Class in org.apache.trevni.avro.mapreduce
An InputFormat for Trevni files.
AvroTrevniKeyInputFormat() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyInputFormat
 
AvroTrevniKeyOutputFormat<T> - Class in org.apache.trevni.avro.mapreduce
An OutputFormat that writes Avro data to Trevni files.
AvroTrevniKeyOutputFormat() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyOutputFormat
 
AvroTrevniKeyRecordReader<T> - Class in org.apache.trevni.avro.mapreduce
Reads records from an input split representing a chunk of an Trenvi container file.
AvroTrevniKeyRecordReader() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordReader
 
AvroTrevniKeyRecordWriter<T> - Class in org.apache.trevni.avro.mapreduce
Writes Trevni records to an Trevni container file output stream.
AvroTrevniKeyRecordWriter(TaskAttemptContext) - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordWriter
Constructor.
AvroTrevniKeyValueInputFormat<K,V> - Class in org.apache.trevni.avro.mapreduce
An InputFormat for Trevni files.
AvroTrevniKeyValueInputFormat() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueInputFormat
 
AvroTrevniKeyValueOutputFormat<K,V> - Class in org.apache.trevni.avro.mapreduce
An OutputFormat that writes Avro data to Trevni files.
AvroTrevniKeyValueOutputFormat() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueOutputFormat
 
AvroTrevniKeyValueRecordReader<K,V> - Class in org.apache.trevni.avro.mapreduce
Reads Trevni generic records from an Trevni container file, where the records contain two fields: 'key' and 'value'.
AvroTrevniKeyValueRecordReader() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordReader
 
AvroTrevniKeyValueRecordWriter<K,V> - Class in org.apache.trevni.avro.mapreduce
Writes key/value pairs to an Trevni container file.
AvroTrevniKeyValueRecordWriter(TaskAttemptContext) - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordWriter
Constructor.
AvroTrevniOutputFormat<T> - Class in org.apache.trevni.avro
An OutputFormat that writes Avro data to Trevni files.
AvroTrevniOutputFormat() - Constructor for class org.apache.trevni.avro.AvroTrevniOutputFormat
 
AvroTrevniRecordReaderBase<K,V,T> - Class in org.apache.trevni.avro.mapreduce
Abstract base class for RecordReaders that read Trevni container files.
AvroTrevniRecordReaderBase() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
 
AvroTrevniRecordWriterBase<K,V,T> - Class in org.apache.trevni.avro.mapreduce
Abstract base class for RecordWriters that writes Trevni container files.
AvroTrevniRecordWriterBase(TaskAttemptContext) - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
Constructor.
AvroTypeException - Exception in org.apache.avro
Thrown when an illegal type is used.
AvroTypeException(String) - Constructor for exception org.apache.avro.AvroTypeException
 
AvroTypeException(String, Throwable) - Constructor for exception org.apache.avro.AvroTypeException
 
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.
await() - Method in class org.apache.avro.ipc.CallFuture
Waits for the CallFuture to complete without returning the result.
await(long, TimeUnit) - Method in class org.apache.avro.ipc.CallFuture
Waits for the CallFuture to complete without returning the result.

B

backup(int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Retreat.
beginColumn - Variable in class org.apache.avro.compiler.idl.Token
The column number of the first character of this Token.
beginLine - Variable in class org.apache.avro.compiler.idl.Token
The line number of the first character of this Token.
BeginToken() - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
BINARY_PREFIX - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key prefix for a binary output metadata.
binaryBlockSize - Variable in class org.apache.avro.io.EncoderFactory
 
binaryBufferSize - Variable in class org.apache.avro.io.EncoderFactory
 
BinaryData - Class in org.apache.avro.io
Utilities for binary-encoded data.
BinaryDecoder - Class in org.apache.avro.io
An Decoder for binary-format data.
BinaryDecoder() - Constructor for class org.apache.avro.io.BinaryDecoder
protected constructor for child classes
binaryDecoder(InputStream, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
Creates or reinitializes a BinaryDecoder with the input stream provided as the source of data.
binaryDecoder(byte[], int, int, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
Creates or reinitializes a BinaryDecoder with the byte array provided as the source of data.
binaryDecoder(byte[], BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
This method is shorthand for
BinaryEncoder - Class in org.apache.avro.io
An abstract Encoder for Avro's binary encoding.
BinaryEncoder() - Constructor for class org.apache.avro.io.BinaryEncoder
 
binaryEncoder(OutputStream, BinaryEncoder) - Method in class org.apache.avro.io.EncoderFactory
Creates or reinitializes a BinaryEncoder with the OutputStream provided as the destination for written data.
BinaryFragmentToJsonTool - Class in org.apache.avro.tool
Converts an input file from Avro binary into JSON.
BinaryFragmentToJsonTool() - Constructor for class org.apache.avro.tool.BinaryFragmentToJsonTool
 
bldr - Variable in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
 
blockFinished() - Method in class org.apache.avro.file.DataFileReader
 
blockFinished() - Method in class org.apache.avro.file.DataFileStream
 
BlockingBinaryEncoder - Class in org.apache.avro.io
A BinaryEncoder implementation that writes large arrays and maps as a sequence of blocks.
blockingBinaryEncoder(OutputStream, BinaryEncoder) - Method in class org.apache.avro.io.EncoderFactory
Creates or reinitializes a BinaryEncoder with the OutputStream provided as the destination for written data.
BOOLEAN - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
BOOLEAN - Static variable in class org.apache.avro.io.parsing.Symbol
 
booleanBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build a boolean type that can set custom properties.
booleanBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build a boolean type that can set custom properties.
booleanBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build a boolean type that can set custom properties.
booleanDefault(boolean) - Method in class org.apache.avro.SchemaBuilder.BooleanDefault
Completes this field with the default value provided
booleanType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain boolean type without custom properties.
booleanType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain boolean type without custom properties.
booleanType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain boolean type without custom properties.
bufcolumn - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
buffer - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
buffer - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
BUFFER_SIZE - Static variable in class org.apache.avro.util.ByteBufferOutputStream
 
BufferedBinaryEncoder - Class in org.apache.avro.io
An Encoder for Avro's binary encoding.
bufline - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
bufpos - Variable in class org.apache.avro.compiler.idl.JavaCharStream
Position in buffer.
build() - Method in interface org.apache.avro.data.RecordBuilder
Constructs a new instance using the values set in the RecordBuilder.
build() - Method in class org.apache.avro.generic.GenericRecordBuilder
 
build() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
 
build() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
 
build() - Method in class org.apache.avro.ipc.trace.Span.Builder
 
build() - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
 
buildDefaultBootstrapOptions(Long) - Static method in class org.apache.avro.ipc.NettyTransceiver
Creates the default options map for the Netty ClientBootstrap.
builder() - Static method in class org.apache.avro.SchemaBuilder
Create a builder for Avro schemas.
builder(String) - Static method in class org.apache.avro.SchemaBuilder
Create a builder for Avro schemas with a default namespace.
ByteBufferInputStream - Class in org.apache.avro.util
Utility to present ByteBuffer data as an InputStream.
ByteBufferInputStream(List<ByteBuffer>) - Constructor for class org.apache.avro.util.ByteBufferInputStream
 
ByteBufferOutputStream - Class in org.apache.avro.util
Utility to collect data written to an OutputStream in ByteBuffers.
ByteBufferOutputStream() - Constructor for class org.apache.avro.util.ByteBufferOutputStream
 
BYTES - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
bytes(byte[]) - Method in class org.apache.avro.generic.GenericData.Fixed
 
bytes() - Method in class org.apache.avro.generic.GenericData.Fixed
 
bytes() - Method in interface org.apache.avro.generic.GenericFixed
Return the data.
BYTES - Static variable in class org.apache.avro.io.parsing.Symbol
 
bytesBuffered() - Method in class org.apache.avro.io.BinaryEncoder
Returns the number of bytes currently buffered by this encoder.
bytesBuffered() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
bytesBuffered() - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
bytesBuffered() - Method in class org.apache.avro.io.DirectBinaryEncoder
 
bytesBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build a bytes type that can set custom properties.
bytesBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build a bytes type that can set custom properties.
bytesBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build a bytes type that can set custom properties.
bytesDefault(byte[]) - Method in class org.apache.avro.SchemaBuilder.BytesDefault
Completes this field with the default value provided, cannot be null
bytesDefault(ByteBuffer) - Method in class org.apache.avro.SchemaBuilder.BytesDefault
Completes this field with the default value provided, cannot be null
bytesDefault(String) - Method in class org.apache.avro.SchemaBuilder.BytesDefault
Completes this field with the default value provided, cannot be null.
bytesType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain bytes type without custom properties.
bytesType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain bytes type without custom properties.
bytesType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain bytes type without custom properties.
BZIP2_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
 
BZip2Codec - Class in org.apache.avro.file
Implements bzip2 compression and decompression.
BZip2Codec() - Constructor for class org.apache.avro.file.BZip2Codec
 
bzip2Codec() - Static method in class org.apache.avro.file.CodecFactory
bzip2 codec.
BZip2Codec - Class in org.apache.trevni
 
BZip2Codec() - Constructor for class org.apache.trevni.BZip2Codec
 

C

Callback<T> - Interface in org.apache.avro.ipc
Interface for receiving asynchronous callbacks.
callback - Variable in class org.apache.avro.ipc.NettyTransceiver.WriteFutureListener
 
CallFuture<T> - Class in org.apache.avro.ipc
A Future implementation for RPCs.
CallFuture() - Constructor for class org.apache.avro.ipc.CallFuture
Creates a CallFuture.
CallFuture(Callback<T>) - Constructor for class org.apache.avro.ipc.CallFuture
Creates a CallFuture with a chained Callback which will be invoked when this CallFuture's Callback methods are invoked.
cancel(boolean) - Method in class org.apache.avro.ipc.CallFuture
 
CatTool - Class in org.apache.avro.tool
Tool to extract samples from an Avro data file.
CatTool() - Constructor for class org.apache.avro.tool.CatTool
 
channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in class org.apache.avro.ipc.NettyTransceiver.NettyClientAvroHandler
 
CHARACTER_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
charAt(int) - Method in class org.apache.avro.util.Utf8
 
charts - Variable in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
 
checkReaderWriterCompatibility(Schema, Schema) - Static method in class org.apache.avro.SchemaCompatibility
Validates that the provided reader schema can be used to decode avro data written with the provided writer schema.
children - Variable in class org.apache.avro.ipc.trace.TraceNode
A list of this TraceNode's children.
CLASS_PROP - Static variable in class org.apache.avro.specific.SpecificData
 
ClassUtils - Class in org.apache.avro.util
 
clear() - Method in class org.apache.avro.generic.GenericData.Array
 
clear(String) - Method in class org.apache.avro.generic.GenericRecordBuilder
Clears the value of the given field.
clear(Schema.Field) - Method in class org.apache.avro.generic.GenericRecordBuilder
Clears the value of the given field.
clear(int) - Method in class org.apache.avro.generic.GenericRecordBuilder
Clears the value of the given field.
clear() - Method in class org.apache.avro.ipc.trace.FileSpanStorage
Clear all Span data stored by this plugin.
clear() - Method in class org.apache.avro.util.WeakIdentityHashMap
 
clearCause() - Method in interface org.apache.avro.data.ErrorBuilder
Clears the cause
clearCause() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
clearClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Clears the value of the 'clientHash' field
clearClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Clears the value of the 'clientProtocol' field
clearComplete() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'complete' field
clearEvent() - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Clears the value of the 'event' field
clearEvents() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'events' field
clearMatch() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Clears the value of the 'match' field
clearMessageName() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'messageName' field
clearMeta() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Clears the value of the 'meta' field
clearMeta() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Clears the value of the 'meta' field
clearParentSpanID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'parentSpanID' field
clearRequestorHostname() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'requestorHostname' field
clearRequestPayloadSize() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'requestPayloadSize' field
clearResponderHostname() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'responderHostname' field
clearResponsePayloadSize() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'responsePayloadSize' field
clearServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Clears the value of the 'serverHash' field
clearServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Clears the value of the 'serverHash' field
clearServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Clears the value of the 'serverProtocol' field
clearSpanID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'spanID' field
clearTimeStamp() - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Clears the value of the 'timeStamp' field
clearTraceID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Clears the value of the 'traceID' field
clearValue() - Method in interface org.apache.avro.data.ErrorBuilder
Clears the value
clearValue() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
clientFacingServer - Variable in class org.apache.avro.ipc.trace.TracePlugin
 
clientFinishConnect(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
Called on the client after the initial RPC handshake
clientFinishConnect(RPCContext) - Method in class org.apache.avro.ipc.trace.TracePlugin
 
clientHash - Variable in class org.apache.avro.ipc.HandshakeRequest
Deprecated.
clientPort - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
clientProtocol - Variable in class org.apache.avro.ipc.HandshakeRequest
Deprecated.
clientReceiveResponse(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
This method is invoked at the client after the call is executed, and after the client receives the response
clientReceiveResponse(RPCContext) - Method in class org.apache.avro.ipc.stats.StatsPlugin
 
clientReceiveResponse(RPCContext) - Method in class org.apache.avro.ipc.trace.TracePlugin
 
clientSendRequest(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
This method is invoked at the client before it issues the RPC call.
clientSendRequest(RPCContext) - Method in class org.apache.avro.ipc.stats.StatsPlugin
 
clientSendRequest(RPCContext) - Method in class org.apache.avro.ipc.trace.TracePlugin
 
clientStartConnect(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
Called on the client before the initial RPC handshake to setup any handshake metadata for this plugin
clientStartConnect(RPCContext) - Method in class org.apache.avro.ipc.trace.TracePlugin
 
close() - Method in class org.apache.avro.compiler.idl.Idl
 
close() - Method in class org.apache.avro.file.DataFileReader12
Close this reader.
close() - Method in class org.apache.avro.file.DataFileStream
Close this reader.
close() - Method in class org.apache.avro.file.DataFileWriter
Flush and close the file.
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.ipc.DatagramServer
 
close() - Method in class org.apache.avro.ipc.HttpServer
 
close() - Method in class org.apache.avro.ipc.NettyServer
 
close() - Method in class org.apache.avro.ipc.NettyTransceiver
Closes this transceiver and disconnects from the remote peer.
close(boolean) - Method in class org.apache.avro.ipc.NettyTransceiver
Closes this transceiver and disconnects from the remote peer.
close() - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
close() - Method in interface org.apache.avro.ipc.Server
Stop this server.
close() - Method in class org.apache.avro.ipc.SocketServer
Deprecated.
 
close() - Method in class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
close() - Method in class org.apache.avro.ipc.Transceiver
 
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
close() - Method in class org.apache.trevni.avro.AvroColumnReader
 
close() - Method in class org.apache.trevni.avro.HadoopInput
 
close() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
close(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
close() - Method in class org.apache.trevni.ColumnFileReader
 
close() - Method in class org.apache.trevni.InputFile
 
Codec - Class in org.apache.avro.file
Interface for Avro-supported compression codecs for data files.
Codec() - Constructor for class org.apache.avro.file.Codec
 
CODEC - Static variable in class org.apache.avro.file.DataFileConstants
 
CodecFactory - Class in org.apache.avro.file
Encapsulates the ability to specify and configure a compression codec.
CodecFactory() - Constructor for class org.apache.avro.file.CodecFactory
 
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.
collectAllSpans(List<URL>) - Method in class org.apache.avro.ipc.trace.TraceClientServlet
 
collectRangedSpans(List<URL>, long, long) - Method in class org.apache.avro.ipc.trace.TraceClientServlet
 
COLON - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
column - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
ColumnFileMetaData - Class in org.apache.trevni
File-level metadata.
ColumnFileMetaData() - Constructor for class org.apache.trevni.ColumnFileMetaData
 
ColumnFileReader - Class in org.apache.trevni
Reads data from a column file.
ColumnFileReader(File) - Constructor for class org.apache.trevni.ColumnFileReader
Construct reading from the named file.
ColumnFileReader(Input) - Constructor for class org.apache.trevni.ColumnFileReader
Construct reading from the provided input.
ColumnFileWriter - Class in org.apache.trevni
Writes data to a column file.
ColumnFileWriter(ColumnFileMetaData, ColumnMetaData...) - Constructor for class org.apache.trevni.ColumnFileWriter
Construct given metadata for each column in the file.
ColumnMetaData - Class in org.apache.trevni
Metadata for a column.
ColumnMetaData(String, ValueType) - Constructor for class org.apache.trevni.ColumnMetaData
Construct given a name and type.
ColumnValues<T extends Comparable> - Class in org.apache.trevni
An iterator over column values.
COMMA - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
compare(Object, Object, Schema) - Method in class org.apache.avro.generic.GenericData
Compare objects according to their schema.
compare(Object, Object, Schema, boolean) - Method in class org.apache.avro.generic.GenericData
Comparison implementation.
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, byte[], int, Schema) - Static method in class org.apache.avro.io.BinaryData
Compare binary encoded data.
compare(byte[], int, int, byte[], int, int, Schema) - Static method in class org.apache.avro.io.BinaryData
Compare binary encoded data.
compare(Trace, Trace) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceComparotor
 
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
 
compare(Object, Object, Schema, boolean) - Method in class org.apache.avro.reflect.ReflectData
 
compare(Object, Object, Schema, boolean) - Method in class org.apache.avro.specific.SpecificData
 
compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.avro.io.BinaryData
Lexicographically compare bytes.
compareTo(GenericArray<T>) - Method in class org.apache.avro.generic.GenericData.Array
 
compareTo(GenericEnumSymbol) - Method in class org.apache.avro.generic.GenericData.EnumSymbol
 
compareTo(GenericData.Fixed) - Method in class org.apache.avro.generic.GenericData.Fixed
 
compareTo(GenericData.Record) - Method in class org.apache.avro.generic.GenericData.Record
 
compareTo(TraceCollection.TraceTiming) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceTiming
 
compareTo(Pair) - Method in class org.apache.avro.mapred.Pair
 
compareTo(SpecificRecord) - Method in class org.apache.avro.specific.SpecificRecordBase
 
compareTo(Utf8) - Method in class org.apache.avro.util.Utf8
 
CompilationUnit() - Method in class org.apache.avro.compiler.idl.Idl
The input to Idl is a CompilationUnit, which is currently just a single Protocol.
compileProtocol(File, File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates Java interface and classes for a protocol.
compileProtocol(File[], File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates Java interface and classes for a number of protocol files.
compileSchema(File, File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates Java classes for a schema.
compileSchema(File[], File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates Java classes for a number of schema files.
compileToDestination(File, File) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Generate output under dst, unless existing file is newer than src.
complete - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
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.
completeSpans - Variable in class org.apache.avro.ipc.trace.SpanAggregator.SpanAggregationResults
Spans which have data from client and server.
compress(ByteBuffer) - Method in class org.apache.avro.file.BZip2Codec
 
compress(ByteBuffer) - Method in class org.apache.avro.file.Codec
Compresses the input data
compress(ByteBuffer) - Method in class org.apache.avro.file.XZCodec
 
compressionLevel - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
ConcatTool - Class in org.apache.avro.tool
Tool to concatenate avro files with the same schema and non-reserved metatdata.
ConcatTool() - Constructor for class org.apache.avro.tool.ConcatTool
 
CONF_OUTPUT_CODEC - Static variable in class org.apache.avro.mapreduce.AvroJob
The configuration key for a job's output compression codec.
config - Variable in class org.apache.avro.ipc.trace.TracePlugin
 
configure(InputStream) - Method in class org.apache.avro.io.JsonDecoder
Reconfigures this JsonDecoder to use the InputStream provided.
configure(String) - Method in class org.apache.avro.io.JsonDecoder
Reconfigures this JsonDecoder to use the String provided for input.
configure(OutputStream) - Method in class org.apache.avro.io.JsonEncoder
Reconfigures this JsonEncoder to use the output stream provided.
configure(JsonGenerator) - Method in class org.apache.avro.io.JsonEncoder
Reconfigures this JsonEncoder to output to the JsonGenerator provided.
configure(Decoder) - Method in class org.apache.avro.io.ValidatingDecoder
Re-initialize, reading from a new underlying Decoder.
configure(Encoder) - Method in class org.apache.avro.io.ValidatingEncoder
Reconfigures this ValidatingEncoder to wrap the encoder provided.
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.
configureBlockSize(int) - Method in class org.apache.avro.io.EncoderFactory
Configures this factory to construct blocking BinaryEncoders with the specified block buffer size.
configureBufferSize(int) - Method in class org.apache.avro.io.EncoderFactory
Configures this factory to use the specified buffer size when creating Encoder instances that buffer their output.
configureDecoderBufferSize(int) - Method in class org.apache.avro.io.DecoderFactory
Configures this factory to use the specified buffer size when creating Decoder instances that buffer their input.
configureSingleton(TracePluginConfiguration) - Static method in class org.apache.avro.ipc.trace.TracePlugin
Configure a singleton instance for this TracePlugin.
containsKey(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
 
containsValue(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
 
contents - Variable in class org.apache.avro.io.parsing.Symbol.DefaultStartAction
 
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(Schema, File) - Method in class org.apache.avro.file.DataFileWriter
Open a new file for data matching a schema.
create(Schema, OutputStream) - Method in class org.apache.avro.file.DataFileWriter
Open a new file for data matching a schema.
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.
create(Schema.Type) - Static method in class org.apache.avro.Schema
Create a schema for a primitive type.
createArray(Schema) - Static method in class org.apache.avro.Schema
Create an array schema.
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.
createBinaryDecoder(InputStream, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
Deprecated.
createBinaryDecoder(byte[], int, int, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
createBinaryDecoder(byte[], BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
createBytes(byte[]) - Method in class org.apache.avro.generic.GenericDatumReader
Called to create byte arrays from default values.
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
 
createDatumReader(Schema) - Method in class org.apache.avro.generic.GenericData
Returns a DatumReader for this kind of data.
createDatumReader(Schema, Schema) - Method in class org.apache.avro.generic.GenericData
Returns a DatumReader for this kind of data.
createDatumReader(Schema) - Method in class org.apache.avro.protobuf.ProtobufData
 
createDatumReader(Schema) - Method in class org.apache.avro.reflect.ReflectData
 
createDatumReader(Schema, Schema) - Method in class org.apache.avro.reflect.ReflectData
 
createDatumReader(Schema) - Method in class org.apache.avro.specific.SpecificData
 
createDatumReader(Schema, Schema) - Method in class org.apache.avro.specific.SpecificData
 
createDatumReader(Schema) - Method in class org.apache.avro.thrift.ThriftData
 
createDatumWriter(Schema) - Method in class org.apache.avro.generic.GenericData
Returns a DatumWriter for this kind of data.
createDatumWriter(Schema) - Method in class org.apache.avro.protobuf.ProtobufData
 
createDatumWriter(Schema) - Method in class org.apache.avro.reflect.ReflectData
 
createDatumWriter(Schema) - Method in class org.apache.avro.specific.SpecificData
 
createDatumWriter(Schema) - Method in class org.apache.avro.thrift.ThriftData
 
createEnum(String, Schema) - Method in class org.apache.avro.generic.GenericData
Called to create an enum value.
createEnum(String, Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Called to create an enum value.
createEnum(String, Schema) - Method in class org.apache.avro.protobuf.ProtobufDatumReader
 
createEnum(String, String, String, List<String>) - Static method in class org.apache.avro.Schema
Create an enum schema.
createEnum(String, Schema) - Method in class org.apache.avro.specific.SpecificData
 
createEnum(String, Schema) - Method in class org.apache.avro.thrift.ThriftDatumReader
 
createFieldSchema(Field, Map<String, Schema>) - Method in class org.apache.avro.reflect.ReflectData.AllowNull
 
createFieldSchema(Field, Map<String, Schema>) - Method in class org.apache.avro.reflect.ReflectData
Create a schema for a field.
createFixed(Object, Schema) - Method in class org.apache.avro.generic.GenericData
Called to create an fixed value.
createFixed(Object, byte[], Schema) - Method in class org.apache.avro.generic.GenericData
Called to create an fixed value.
createFixed(Object, Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Deprecated.
As of Avro 1.6.0 this method has been moved to GenericData.createFixed(Object, Schema)
createFixed(Object, byte[], Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Deprecated.
As of Avro 1.6.0 this method has been moved to GenericData.createFixed(Object, byte[], Schema)
createFixed(String, String, String, int) - Static method in class org.apache.avro.Schema
Create a union schema.
createFixed(Object, Schema) - Method in class org.apache.avro.specific.SpecificData
 
createInputDataModel(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
 
createInstance() - Method in class org.apache.avro.file.CodecFactory
Creates internal Codec.
createKey() - Method in class org.apache.avro.mapred.AvroRecordReader
 
createMap(Schema) - Static method in class org.apache.avro.Schema
Create a map schema.
createMapOutputDataModel(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
 
createMessage(String, String, Schema) - Method in class org.apache.avro.Protocol
Deprecated.
createMessage(String, String, Map<String, T>, Schema) - Method in class org.apache.avro.Protocol
Create a one-way message.
createMessage(String, String, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
Deprecated.
createMessage(String, String, Map<String, T>, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
Create a two-way message.
createNettyClientAvroHandler() - Method in class org.apache.avro.ipc.NettyTransceiver
Creates a Netty ChannelUpstreamHandler for handling events on the Netty client channel.
CreateRandomFileTool - Class in org.apache.avro.tool
Creates a file filled with randomly-generated instances of a schema.
CreateRandomFileTool() - Constructor for class org.apache.avro.tool.CreateRandomFileTool
 
createRecord(List<Schema.Field>) - Static method in class org.apache.avro.Schema
Create an anonymous record schema.
createRecord(String, String, String, boolean) - Static method in class org.apache.avro.Schema
Create a named record schema.
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.trevni.avro.mapreduce.AvroTrevniKeyInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueInputFormat
createSchema(Type, Map<String, Schema>) - Method in class org.apache.avro.reflect.ReflectData
 
createSchema(Type, Map<String, Schema>) - Method in class org.apache.avro.specific.SpecificData
Create the schema for a Java type.
createSeekableInput(Configuration, Path) - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
Creates a seekable input stream to an Avro container file.
createServer(Responder, URI) - Static method in class org.apache.avro.ipc.Ipc
Create a Server listening at the named URI using the provided responder.
createSetters - Variable in class org.apache.avro.mojo.AbstractAvroMojo
Determines whether or not to create setters for the fields of the record.
createString(String) - Method in class org.apache.avro.generic.GenericDatumReader
Called to create a string from a default value.
createString(String) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
createTransceiver(URI) - Static method in class org.apache.avro.ipc.Ipc
Create a client Transceiver connecting to the provided URI.
createUnion(List<Schema>) - Static method in class org.apache.avro.Schema
Create a union schema.
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.
curChar - Variable in class org.apache.avro.compiler.idl.IdlTokenManager
 
currentToken - Variable in exception org.apache.avro.compiler.idl.ParseException
This is the last token that has been consumed successfully.
CustomEncoding<T> - Class in org.apache.avro.reflect
Expert: a custom encoder and decoder that writes an object directly to avro.
CustomEncoding() - Constructor for class org.apache.avro.reflect.CustomEncoding
 

D

DASH - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
data() - Method in class org.apache.avro.data.RecordBuilderBase
 
DATA_FILENAME - Static variable in class org.apache.avro.hadoop.file.SortedKeyValueFile
The name of the data file within the SortedKeyValueFile directory.
DataFileConstants - Class in org.apache.avro.file
Constants used in data files.
DataFileGetMetaTool - Class in org.apache.avro.tool
Reads a data file to get its metadata.
DataFileGetMetaTool() - Constructor for class org.apache.avro.tool.DataFileGetMetaTool
 
DataFileGetSchemaTool - Class in org.apache.avro.tool
Reads a data file to get its schema.
DataFileGetSchemaTool() - Constructor for class org.apache.avro.tool.DataFileGetSchemaTool
 
DataFileReader<D> - Class in org.apache.avro.file
Random access to files written with DataFileWriter.
DataFileReader(File, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileReader
Construct a reader for a file.
DataFileReader(SeekableInput, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileReader
Construct a reader for a file.
DataFileReader(SeekableInput, DatumReader<D>, DataFileStream.Header) - Constructor for class org.apache.avro.file.DataFileReader
Construct using a DataFileStream.Header.
DataFileReader12<D> - Class in org.apache.avro.file
Read files written by Avro version 1.2.
DataFileReader12(SeekableInput, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileReader12
Construct a reader for a file.
DataFileReadTool - Class in org.apache.avro.tool
Reads a data file and dumps to JSON
DataFileReadTool() - Constructor for class org.apache.avro.tool.DataFileReadTool
 
DataFileStream<D> - Class in org.apache.avro.file
Streaming access to files written by DataFileWriter.
DataFileStream(InputStream, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileStream
Construct a reader for an input stream.
DataFileStream(DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileStream
create an unitialized DataFileStream
DataFileStream.Header - Class in org.apache.avro.file
A handle that can be used to reopen a DataFile without re-reading the header of the stream.
DataFileWriter<D> - Class in org.apache.avro.file
Stores in a file a sequence of data conforming to a schema.
DataFileWriter(DatumWriter<D>) - Constructor for class org.apache.avro.file.DataFileWriter
Construct a writer, not yet open.
DataFileWriter.AppendWriteException - Exception in org.apache.avro.file
Thrown by DataFileWriter.append(Object) when an exception occurs while writing a datum to the buffer.
DataFileWriter.AppendWriteException(Exception) - Constructor for exception org.apache.avro.file.DataFileWriter.AppendWriteException
 
DataFileWriteTool - Class in org.apache.avro.tool
Reads new-line delimited JSON records and writers an Avro data file.
DataFileWriteTool() - Constructor for class org.apache.avro.tool.DataFileWriteTool
 
DatagramServer - Class in org.apache.avro.ipc
A datagram-based server implementation.
DatagramServer(Responder, SocketAddress) - Constructor for class org.apache.avro.ipc.DatagramServer
 
DatagramTransceiver - Class in org.apache.avro.ipc
A datagram-based Transceiver implementation.
DatagramTransceiver(SocketAddress) - Constructor for class org.apache.avro.ipc.DatagramTransceiver
 
DatagramTransceiver(DatagramChannel) - Constructor for class org.apache.avro.ipc.DatagramTransceiver
 
DateAsLongEncoding - Class in org.apache.avro.reflect
This encoder/decoder writes a java.util.Date object as a long to avro and reads a Date object from long.
DateAsLongEncoding() - Constructor for class org.apache.avro.reflect.DateAsLongEncoding
 
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.
DatumReader<D> - Interface in org.apache.avro.io
Read data of a schema.
DatumWriter<D> - Interface in org.apache.avro.io
Write data of a schema.
debugStream - Variable in class org.apache.avro.compiler.idl.IdlTokenManager
Debug output.
DECIMAL_EXPONENT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
DECIMAL_FLOATING_POINT_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
DECIMAL_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class org.apache.avro.ipc.NettyTransportCodec.NettyFrameDecoder
decode buffer to NettyDataPack
Decoder - Class in org.apache.avro.io
Low-level support for de-serializing Avro values.
Decoder() - Constructor for class org.apache.avro.io.Decoder
 
DecoderFactory - Class in org.apache.avro.io
A factory for creating and configuring Decoders.
DecoderFactory() - Constructor for class org.apache.avro.io.DecoderFactory
Constructor for factory instances
decompress(ByteBuffer) - Method in class org.apache.avro.file.BZip2Codec
 
decompress(ByteBuffer) - Method in class org.apache.avro.file.Codec
Decompress the data
decompress(ByteBuffer) - Method in class org.apache.avro.file.XZCodec
 
deepCopy(Schema, T) - Method in class org.apache.avro.generic.GenericData
Makes a deep copy of a value given its schema.
DEFAULT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
Lexical state.
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.avro.file.BZip2Codec
 
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.trevni.BZip2Codec
 
DEFAULT_BUFFER_SIZE_BYTES - Static variable in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
The default write buffer size in bytes.
DEFAULT_CLIENT_PORT - Static variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
DEFAULT_CONNECTION_TIMEOUT_MILLIS - Static variable in class org.apache.avro.ipc.NettyTransceiver
If not specified, the default connection timeout will be used (60 sec).
DEFAULT_DEFLATE_LEVEL - Static variable in class org.apache.avro.file.CodecFactory
 
DEFAULT_END_ACTION - Static variable in class org.apache.avro.io.parsing.Symbol
 
DEFAULT_MAX_SPANS - Static variable in interface org.apache.avro.ipc.trace.SpanStorage
 
DEFAULT_PORT - Static variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
DEFAULT_SYNC_INTERVAL - Static variable in class org.apache.avro.file.DataFileConstants
 
DEFAULT_TCP_NODELAY_VALUE - Static variable in class org.apache.avro.ipc.NettyTransceiver
 
DEFAULT_XZ_LEVEL - Static variable in class org.apache.avro.file.CodecFactory
 
defaultFactory() - Static method in class org.apache.avro.io.DecoderFactory
Deprecated.
use the equivalent DecoderFactory.get() instead
defaultStartAction(byte[]) - Static method in class org.apache.avro.io.parsing.Symbol
 
defaultValue(Schema.Field) - Method in class org.apache.avro.data.RecordBuilderBase
Gets the default value of the given field, if any.
defaultValue() - Method in class org.apache.avro.Schema.Field
 
DEFLATE_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
 
DEFLATE_LEVEL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The configuration key for Avro deflate level.
deflateCodec(int) - Static method in class org.apache.avro.file.CodecFactory
Deflate codec, with specific compression.
deprecatedFields() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
 
depth() - Method in class org.apache.avro.io.parsing.Parser
Returns the depth of the stack.
depth() - Method in class org.apache.avro.io.ParsingEncoder
 
deserialize(T) - Method in class org.apache.avro.hadoop.io.AvroDeserializer
directBinaryDecoder(InputStream, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
Creates or reinitializes a BinaryDecoder with the input stream provided as the source of data.
DirectBinaryEncoder - Class in org.apache.avro.io
An Encoder for Avro's binary encoding that does not buffer output.
directBinaryEncoder(OutputStream, BinaryEncoder) - Method in class org.apache.avro.io.EncoderFactory
Creates or reinitializes a BinaryEncoder with the OutputStream provided as the destination for written data.
disable_tracing() - Method in class org.apache.avro.compiler.idl.Idl
Disable tracing.
doAction(Symbol, Symbol) - Method in class org.apache.avro.io.JsonDecoder
 
doAction(Symbol, Symbol) - Method in class org.apache.avro.io.JsonEncoder
 
doAction(Symbol, Symbol) - Method in interface org.apache.avro.io.parsing.Parser.ActionHandler
Handle the action symbol top when the input is sought to be taken off the stack.
doAction(Symbol, Symbol) - Method in class org.apache.avro.io.ResolvingDecoder
 
doAction(Symbol, Symbol) - Method in class org.apache.avro.io.ValidatingDecoder
 
doAction(Symbol, Symbol) - Method in class org.apache.avro.io.ValidatingEncoder
 
doc() - Method in class org.apache.avro.Schema.Field
Field's documentation within the record, if set.
doc(String) - Method in class org.apache.avro.SchemaBuilder.NamedBuilder
configure this type's optional documentation string
DOC_COMMENT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
Lexical state.
doCompile(File, File) - Method in class org.apache.avro.compiler.specific.ProtocolTask
 
doCompile(File, File) - Method in class org.apache.avro.compiler.specific.SchemaTask
 
doCompile(String, File, File) - Method in class org.apache.avro.mojo.AbstractAvroMojo
 
doCompile(String, File, File) - Method in class org.apache.avro.mojo.IDLProtocolMojo
 
doCompile(String, File, File) - Method in class org.apache.avro.mojo.ProtocolMojo
 
doCompile(String, File, File) - Method in class org.apache.avro.mojo.SchemaMojo
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.stats.StatsServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.trace.TraceClientServlet
We support the following URL patterns /overview/ Show all execution patterns /collection/[p_id] Show details for pattern with [p_id] /collection/[p_id]/[n_id]/ Show trace node with [n_id]
Done() - Method in class org.apache.avro.compiler.idl.JavaCharStream
Set buffers back to null when finished.
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.ResponderServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.trace.TraceClientServlet
 
doReadBytes(byte[], int, int) - Method in class org.apache.avro.io.BinaryDecoder
Reads length bytes into bytes starting at start.
doReadItemCount() - Method in class org.apache.avro.io.BinaryDecoder
Returns the number of items to follow in the current array or map.
doSkipBytes(long) - Method in class org.apache.avro.io.BinaryDecoder
 
DOT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
DOUBLE - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
DOUBLE - Static variable in class org.apache.avro.io.parsing.Symbol
 
doubleBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build a double type that can set custom properties.
doubleBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build a double type that can set custom properties.
doubleBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build a double type that can set custom properties.
doubleDefault(double) - Method in class org.apache.avro.SchemaBuilder.DoubleDefault
Completes this field with the default value provided
doubleType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain double type without custom properties.
doubleType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain double type without custom properties.
doubleType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain double type without custom properties.
drain() - Method in class org.apache.avro.io.ResolvingDecoder
Consume any more data that has been written by the writer but not needed by the reader so that the the underlying decoder is in proper shape for the next record.
dump(Input, PrintStream, boolean) - Method in class org.apache.avro.tool.TrevniMetadataTool
Read a Trevni file and print each row as a JSON object.

E

ELEMENT_PROP - Static variable in class org.apache.avro.specific.SpecificData
 
enable_tracing() - Method in class org.apache.avro.compiler.idl.Idl
Enable tracing.
enabled - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
encode(Encoder, Schema, JsonNode) - Static method in class org.apache.avro.io.parsing.ResolvingGrammarGenerator
Encodes the given Json node n on to the encoder e according to the schema s.
encode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.avro.ipc.NettyTransportCodec.NettyFrameEncoder
encode msg to ChannelBuffer
encodeBoolean(boolean, byte[], int) - Static method in class org.apache.avro.io.BinaryData
Encode a boolean to the byte array at the given position.
encodeDouble(double, byte[], int) - Static method in class org.apache.avro.io.BinaryData
Encode a double to the byte array at the given position.
encodeFloat(float, byte[], int) - Static method in class org.apache.avro.io.BinaryData
Encode a float to the byte array at the given position.
encodeInt(int, byte[], int) - Static method in class org.apache.avro.io.BinaryData
Encode an integer to the byte array at the given position.
encodeLong(long, byte[], int) - Static method in class org.apache.avro.io.BinaryData
Encode a long to the byte array at the given position.
Encoder - Class in org.apache.avro.io
Low-level support for serializing Avro values.
Encoder() - Constructor for class org.apache.avro.io.Encoder
 
EncoderFactory - Class in org.apache.avro.io
A factory for creating and configuring Encoder instances.
EncoderFactory() - Constructor for class org.apache.avro.io.EncoderFactory
 
end - Variable in class org.apache.avro.io.parsing.Symbol.Repeater
 
endBoolean() - Method in class org.apache.avro.SchemaBuilder.BooleanBuilder
complete building this type, return control to context
endBytes() - Method in class org.apache.avro.SchemaBuilder.BytesBuilder
complete building this type, return control to context
endColumn - Variable in class org.apache.avro.compiler.idl.Token
The column number of the last character of this Token.
endDouble() - Method in class org.apache.avro.SchemaBuilder.DoubleBuilder
complete building this type, return control to context
endFloat() - Method in class org.apache.avro.SchemaBuilder.FloatBuilder
complete building this type, return control to context
endInt() - Method in class org.apache.avro.SchemaBuilder.IntBuilder
complete building this type, return control to context
endLine - Variable in class org.apache.avro.compiler.idl.Token
The line number of the last character of this Token.
endLong() - Method in class org.apache.avro.SchemaBuilder.LongBuilder
complete building this type, return control to context
endNull() - Method in class org.apache.avro.SchemaBuilder.NullBuilder
complete building this type, return control to context
endRecord() - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
End adding fields to this record, returning control to the context that this record builder was created in.
endRow() - Method in class org.apache.trevni.ColumnFileWriter
Expert: Called after all values are written to a row.
endString() - Method in class org.apache.avro.SchemaBuilder.StringBldr
complete building this type, return control to context
endUnion() - Method in class org.apache.avro.SchemaBuilder.UnionAccumulator
Complete this union
entrySet() - Method in class org.apache.avro.util.WeakIdentityHashMap
 
ENUM - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
ENUM - Static variable in class org.apache.avro.io.parsing.Symbol
 
enumAdjustAction(int, Object[]) - Static method in class org.apache.avro.io.parsing.Symbol
 
EnumBody() - Method in class org.apache.avro.compiler.idl.Idl
 
EnumConstant(List<String>) - Method in class org.apache.avro.compiler.idl.Idl
 
EnumDeclaration() - Method in class org.apache.avro.compiler.idl.Idl
 
enumDefault(String) - Method in class org.apache.avro.SchemaBuilder.EnumDefault
Completes this field with the default value provided, cannot be null
enumeration(String) - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build an Avro enum type.
enumeration(String) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build an Avro enum type.
enumeration(String) - Static method in class org.apache.avro.SchemaBuilder
Create a builder for an Avro enum with the specified name and symbols (values).
enumeration(String) - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build an Avro enum type.
enumLabelsAction(List<String>) - Static method in class org.apache.avro.io.parsing.Symbol
For JSON.
EOF - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
End of File.
eol - Variable in exception org.apache.avro.compiler.idl.ParseException
The end of line string for this machine.
EQUALS - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
equals(Object) - Method in class org.apache.avro.data.RecordBuilderBase
 
equals(Object) - Method in class org.apache.avro.file.BZip2Codec
 
equals(Object) - Method in class org.apache.avro.file.Codec
Codecs must implement an equals() method.
equals(Object) - Method in class org.apache.avro.file.XZCodec
 
equals(Object) - Method in class org.apache.avro.generic.GenericData.EnumSymbol
 
equals(Object) - Method in class org.apache.avro.generic.GenericData.Fixed
 
equals(Object) - Method in class org.apache.avro.generic.GenericData.Record
 
equals(Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
 
equals(Object) - Method in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
equals(Object) - Method in class org.apache.avro.mapred.AvroWrapper
 
equals(Object) - Method in class org.apache.avro.mapred.Pair
 
equals(Object) - Method in class org.apache.avro.Protocol
 
equals(Object) - Method in class org.apache.avro.Protocol.Message
 
equals(Object) - Method in class org.apache.avro.Schema
 
equals(Object) - Method in class org.apache.avro.Schema.Field
 
equals(Object) - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
equals(Object) - Method in exception org.apache.avro.specific.SpecificExceptionBase
 
equals(Object) - Method in class org.apache.avro.specific.SpecificRecordBase
 
equals(Object) - Method in class org.apache.avro.util.Utf8
 
equals(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
 
ERROR - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
error - Variable in class org.apache.avro.ipc.RPCContext
 
error() - Method in class org.apache.avro.ipc.RPCContext
The exception generated at the server, or null if no such exception has occured
ErrorBuilder<T> - Interface in org.apache.avro.data
Interface for error builders
ErrorList(List<Schema>) - Method in class org.apache.avro.compiler.idl.Idl
 
escapeForJavadoc(String) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
escapeStringArray(List<String>) - Static method in class org.apache.avro.ipc.stats.StatsServlet
 
event - Variable in class org.apache.avro.ipc.trace.TimestampedEvent
Deprecated.
events - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.apache.avro.ipc.NettyTransceiver.NettyClientAvroHandler
 
excludes - Variable in class org.apache.avro.mojo.AbstractAvroMojo
A set of Ant-like exclusion patterns used to prevent certain files from being processed.
execute() - Method in class org.apache.avro.compiler.specific.ProtocolTask
Run the compiler.
execute() - Method in class org.apache.avro.mojo.AbstractAvroMojo
 
execute() - Method in class org.apache.avro.mojo.HelpMojo
executionPathHash() - Method in class org.apache.avro.ipc.trace.Trace
Provide a hashCode unique to the execution path of this trace.
ExpandBuff(boolean) - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
expectedTokenSequences - Variable in exception org.apache.avro.compiler.idl.ParseException
Each entry in this array is an array of integers.
EXT - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The file name extension for avro data files.
EXT - Static variable in class org.apache.trevni.avro.AvroTrevniOutputFormat
The file name extension for trevni files.
EXT - Static variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
trevni file extension
extractEventTime(TraceNode, SpanEvent) - Method in class org.apache.avro.ipc.trace.TraceNode
Return the time stamp associated with a particular SpanEvent in this Trace Node.
extractTrace(List<Span>) - Static method in class org.apache.avro.ipc.trace.Trace
Construct a Trace from a list of Span objects.

F

fail(String) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Called by a failing task to abort.
FALSE - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
FIELD_ACTION - Static variable in class org.apache.avro.io.parsing.Symbol
 
FIELD_END - Static variable in class org.apache.avro.io.parsing.Symbol
 
fieldAdjustAction(int, String) - Static method in class org.apache.avro.io.parsing.Symbol
 
FieldDeclaration(List<Schema.Field>) - Method in class org.apache.avro.compiler.idl.Idl
 
fieldOrderAction(Schema.Field[]) - Static method in class org.apache.avro.io.parsing.Symbol
 
fields() - Method in class org.apache.avro.data.RecordBuilderBase
 
fields - Variable in class org.apache.avro.io.parsing.Symbol.FieldOrderAction
 
fields() - Method in class org.apache.avro.SchemaBuilder.RecordBuilder
 
fieldSetFlags() - Method in class org.apache.avro.data.RecordBuilderBase
 
fileGranularitySeconds - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
FileReader<D> - Interface in org.apache.avro.file
Interface for reading data from a file.
FileSpanStorage - Class in org.apache.avro.ipc.trace
A file-based { @link SpanStorage } implementation for Avro's { @link TracePlugin }.
FileSpanStorage(boolean, TracePluginConfiguration) - Constructor for class org.apache.avro.ipc.trace.FileSpanStorage
 
FillBuff() - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
findLabel(String) - Method in class org.apache.avro.io.parsing.Symbol.Alternative
 
findLabel(String) - Method in class org.apache.avro.io.parsing.Symbol.EnumLabelsAction
 
findStringClass(Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Determines the class to used to represent a string Schema.
findStringClass(Schema) - Method in class org.apache.avro.specific.SpecificDatumReader
 
fingerprint(String, byte[]) - Static method in class org.apache.avro.SchemaNormalization
Returns a fingerprint of a string of bytes.
fingerprint64(byte[]) - Static method in class org.apache.avro.SchemaNormalization
Returns the 64-bit Rabin Fingerprint (as recommended in the Avro spec) of a byte string.
FIXED - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
FIXED - Static variable in class org.apache.avro.io.parsing.Symbol
 
fixed(String) - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build an Avro fixed type.
fixed(String) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build an Avro fixed type.
fixed(String) - Static method in class org.apache.avro.SchemaBuilder
Create a builder for an Avro fixed type with the specified name and size.
fixed(String) - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build an Avro fixed type.
FixedDeclaration() - Method in class org.apache.avro.compiler.idl.Idl
 
fixedDefault(byte[]) - Method in class org.apache.avro.SchemaBuilder.FixedDefault
Completes this field with the default value provided, cannot be null
fixedDefault(ByteBuffer) - Method in class org.apache.avro.SchemaBuilder.FixedDefault
Completes this field with the default value provided, cannot be null
fixedDefault(String) - Method in class org.apache.avro.SchemaBuilder.FixedDefault
Completes this field with the default value provided, cannot be null.
FixedSize - Annotation Type in org.apache.avro.specific
Declares the size of implementations of GenericFixed.
flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.Alternative
 
flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol
 
flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.Repeater
 
flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.ResolvingAction
 
flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.Sequence
 
flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.SkipAction
 
flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
 
flattenedSize() - Method in class org.apache.avro.io.parsing.Symbol
 
flattenedSize(Symbol[], int) - Static method in class org.apache.avro.io.parsing.Symbol
Returns the amount of space required to flatten the given sub-array of symbols.
flattenedSize() - Method in class org.apache.avro.io.parsing.Symbol.Sequence
 
FLOAT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
FLOAT - Static variable in class org.apache.avro.io.parsing.Symbol
 
floatBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build a float type that can set custom properties.
floatBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build a float type that can set custom properties.
floatBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build a float type that can set custom properties.
floatDefault(float) - Method in class org.apache.avro.SchemaBuilder.FloatDefault
Completes this field with the default value provided
FLOATING_POINT_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
floatType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain float type without custom properties.
floatType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain float type without custom properties.
floatType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain float type without custom properties.
flush() - Method in class org.apache.avro.file.DataFileWriter
Calls DataFileWriter.sync() and then flushes the current state of the file.
flush() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
flush() - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
flush() - Method in class org.apache.avro.io.DirectBinaryEncoder
 
flush() - Method in class org.apache.avro.io.JsonEncoder
 
flush() - Method in class org.apache.avro.io.ValidatingEncoder
 
flush() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
A Trevni flush will close the current file and prep a new writer
fname - Variable in class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
 
FOOTER_BLOCK - Static variable in class org.apache.avro.file.DataFileConstants
 
FormalParameter(List<Schema.Field>) - Method in class org.apache.avro.compiler.idl.Idl
 
FormalParameters() - Method in class org.apache.avro.compiler.idl.Idl
 
forName(String) - Static method in class org.apache.avro.util.ClassUtils
Loads a class using the class loader.
forName(Class<?>, String) - Static method in class org.apache.avro.util.ClassUtils
Loads a class using the class loader.
forName(ClassLoader, String) - Static method in class org.apache.avro.util.ClassUtils
Loads a class using the class loader.
forName(String) - Static method in enum org.apache.trevni.ValueType
Return a type given its name.
fromHadoopString(String) - Static method in class org.apache.avro.hadoop.file.HadoopCodecFactory
Maps a hadoop codec name into a CodecFactory.
fromString(String) - Static method in class org.apache.avro.file.CodecFactory
Maps a codec name into a CodecFactory.
FromTextTool - Class in org.apache.avro.tool
Reads a text file into an Avro data file.
FromTextTool() - Constructor for class org.apache.avro.tool.FromTextTool
 
FsInput - Class in org.apache.avro.mapred
FsInput(Path, Configuration) - Constructor for class org.apache.avro.mapred.FsInput
Construct given a path and a configuration.
fSync() - Method in class org.apache.avro.file.DataFileWriter
If this writer was instantiated using a File or using an Syncable instance, this method flushes all buffers for this writer to disk.

G

generate(Schema) - Method in class org.apache.avro.io.parsing.JsonGrammarGenerator
Returns the non-terminal that is the start symbol for the grammar for the grammar for the given schema sc.
generate(Schema, Map<ValidatingGrammarGenerator.LitS, Symbol>) - Method in class org.apache.avro.io.parsing.JsonGrammarGenerator
Returns the non-terminal that is the start symbol for grammar of the given schema sc.
generate(Schema, Schema) - Method in class org.apache.avro.io.parsing.ResolvingGrammarGenerator
Resolves the writer schema writer and the reader schema reader and returns the start symbol for the grammar generated.
generate(Schema, Schema, Map<ValidatingGrammarGenerator.LitS, Symbol>) - Method in class org.apache.avro.io.parsing.ResolvingGrammarGenerator
Resolves the writer schema writer and the reader schema reader and returns the start symbol for the grammar generated.
generate(Schema) - Method in class org.apache.avro.io.parsing.ValidatingGrammarGenerator
Returns the non-terminal that is the start symbol for the grammar for the given schema sc.
generate(Schema, Map<ValidatingGrammarGenerator.LitS, Symbol>) - Method in class org.apache.avro.io.parsing.ValidatingGrammarGenerator
Returns the non-terminal that is the start symbol for the grammar for the given schema sc.
generateClearMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates the name of a field "clear" method.
generateGetMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates the name of a field accessor method.
generateHasMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates the name of a field "has" method.
generateParseException() - Method in class org.apache.avro.compiler.idl.Idl
Generate ParseException.
generateSetMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Generates the name of a field mutator method.
GenericArray<T> - Interface in org.apache.avro.generic
Array that permits reuse of contained elements.
GenericContainer - Interface in org.apache.avro.generic
Contains data of other types.
GenericData - Class in org.apache.avro.generic
Utilities for generic Java data.
GenericData() - Constructor for class org.apache.avro.generic.GenericData
For subclasses.
GenericData(ClassLoader) - Constructor for class org.apache.avro.generic.GenericData
For subclasses.
GenericData.Array<T> - Class in org.apache.avro.generic
Default implementation of an array.
GenericData.Array(int, Schema) - Constructor for class org.apache.avro.generic.GenericData.Array
 
GenericData.Array(Schema, Collection<T>) - Constructor for class org.apache.avro.generic.GenericData.Array
 
GenericData.EnumSymbol - Class in org.apache.avro.generic
Default implementation of GenericEnumSymbol.
GenericData.EnumSymbol(Schema, String) - Constructor for class org.apache.avro.generic.GenericData.EnumSymbol
 
GenericData.Fixed - Class in org.apache.avro.generic
Default implementation of GenericFixed.
GenericData.Fixed(Schema) - Constructor for class org.apache.avro.generic.GenericData.Fixed
 
GenericData.Fixed(Schema, byte[]) - Constructor for class org.apache.avro.generic.GenericData.Fixed
 
GenericData.Fixed() - Constructor for class org.apache.avro.generic.GenericData.Fixed
 
GenericData.Record - Class in org.apache.avro.generic
Default implementation of GenericRecord.
GenericData.Record(Schema) - Constructor for class org.apache.avro.generic.GenericData.Record
 
GenericData.Record(GenericData.Record, boolean) - Constructor for class org.apache.avro.generic.GenericData.Record
 
GenericData.StringType - Enum in org.apache.avro.generic
Used to specify the Java type for a string schema.
GenericDatumReader<D> - Class in org.apache.avro.generic
DatumReader for generic Java objects.
GenericDatumReader() - Constructor for class org.apache.avro.generic.GenericDatumReader
 
GenericDatumReader(Schema) - Constructor for class org.apache.avro.generic.GenericDatumReader
Construct where the writer's and reader's schemas are the same.
GenericDatumReader(Schema, Schema) - Constructor for class org.apache.avro.generic.GenericDatumReader
Construct given writer's and reader's schema.
GenericDatumReader(Schema, Schema, GenericData) - Constructor for class org.apache.avro.generic.GenericDatumReader
 
GenericDatumReader(GenericData) - Constructor for class org.apache.avro.generic.GenericDatumReader
 
GenericDatumWriter<D> - Class in org.apache.avro.generic
DatumWriter for generic Java objects.
GenericDatumWriter() - Constructor for class org.apache.avro.generic.GenericDatumWriter
 
GenericDatumWriter(GenericData) - Constructor for class org.apache.avro.generic.GenericDatumWriter
 
GenericDatumWriter(Schema) - Constructor for class org.apache.avro.generic.GenericDatumWriter
 
GenericDatumWriter(Schema, GenericData) - Constructor for class org.apache.avro.generic.GenericDatumWriter
 
GenericEnumSymbol - Interface in org.apache.avro.generic
An enum symbol.
GenericFixed - Interface in org.apache.avro.generic
Fixed-size data.
GenericRecord - Interface in org.apache.avro.generic
A generic instance of a record schema.
GenericRecordBuilder - Class in org.apache.avro.generic
A RecordBuilder for generic records.
GenericRecordBuilder(Schema) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
Creates a GenericRecordBuilder for building Record instances.
GenericRecordBuilder(GenericRecordBuilder) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
Creates a GenericRecordBuilder by copying an existing GenericRecordBuilder.
GenericRecordBuilder(GenericData.Record) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
Creates a GenericRecordBuilder by copying an existing record instance.
GenericRequestor - Class in org.apache.avro.ipc.generic
Requestor implementation for generic Java data.
GenericRequestor(Protocol, Transceiver) - Constructor for class org.apache.avro.ipc.generic.GenericRequestor
 
GenericRequestor(Protocol, Transceiver, GenericData) - Constructor for class org.apache.avro.ipc.generic.GenericRequestor
 
GenericResponder - Class in org.apache.avro.ipc.generic
Responder implementation for generic Java data.
GenericResponder(Protocol) - Constructor for class org.apache.avro.ipc.generic.GenericResponder
 
GenericResponder(Protocol, GenericData) - Constructor for class org.apache.avro.ipc.generic.GenericResponder
 
get(int) - Method in class org.apache.avro.generic.GenericData.Array
 
get() - Static method in class org.apache.avro.generic.GenericData
Return the singleton instance.
get(String) - Method in class org.apache.avro.generic.GenericData.Record
 
get(int) - Method in class org.apache.avro.generic.GenericData.Record
 
get(String) - Method in interface org.apache.avro.generic.GenericRecord
Return the value of a field given its name.
get(String) - Method in class org.apache.avro.generic.GenericRecordBuilder
Gets the value of a field.
get(Schema.Field) - Method in class org.apache.avro.generic.GenericRecordBuilder
Gets the value of a field.
get(int) - Method in class org.apache.avro.generic.GenericRecordBuilder
Gets the value of a field.
get(int) - Method in interface org.apache.avro.generic.IndexedRecord
Return the value of a field given its position in the schema.
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() - Static method in class org.apache.avro.io.DecoderFactory
Returns an immutable static DecoderFactory configured with default settings All mutating methods throw IllegalArgumentExceptions.
get() - Static method in class org.apache.avro.io.EncoderFactory
Returns an immutable static DecoderFactory with default configuration.
get(int) - Method in class org.apache.avro.io.parsing.Symbol.Sequence
 
get() - Method in class org.apache.avro.ipc.CallFuture
 
get(long, TimeUnit) - Method in class org.apache.avro.ipc.CallFuture
 
get(int) - Method in class org.apache.avro.ipc.HandshakeRequest
 
get(int) - Method in class org.apache.avro.ipc.HandshakeResponse
 
get(int) - Method in class org.apache.avro.ipc.trace.Span
 
get(int) - Method in class org.apache.avro.ipc.trace.TimestampedEvent
 
get(int) - Method in class org.apache.avro.mapred.Pair
 
get() - Static method in class org.apache.avro.protobuf.ProtobufData
Return the singleton instance.
get() - Static method in class org.apache.avro.reflect.ReflectData.AllowNull
Return the singleton instance.
get() - Static method in class org.apache.avro.reflect.ReflectData
Return the singleton instance.
get() - Static method in class org.apache.avro.specific.SpecificData
Return the singleton instance.
get(int) - Method in exception org.apache.avro.specific.SpecificExceptionBase
 
get(int) - Method in class org.apache.avro.specific.SpecificRecordBase
 
get(String) - Method in class org.apache.avro.specific.SpecificRecordBase
 
get() - Static method in class org.apache.avro.thrift.ThriftData
Return the singleton instance.
get(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
 
getAliases() - Method in class org.apache.avro.Schema
If this is a record, enum or fixed, return its aliases, if any.
getAllSpans(Callback<List<Span>>) - Method in interface org.apache.avro.ipc.trace.AvroTrace.Callback
Get all spans stored on this host.
getAllSpans() - Method in interface org.apache.avro.ipc.trace.AvroTrace
Get all spans stored on this host.
getAllSpans() - Method in class org.apache.avro.ipc.trace.FileSpanStorage
 
getAllSpans() - Method in class org.apache.avro.ipc.trace.InMemorySpanStorage
 
getAllSpans() - Method in interface org.apache.avro.ipc.trace.SpanStorage
Return a list of all spans currently stored.
getArrayElements(Object) - Method in class org.apache.avro.generic.GenericDatumWriter
Called by the default implementation of GenericDatumWriter.writeArray(org.apache.avro.Schema, java.lang.Object, org.apache.avro.io.Encoder) to enumerate array elements.
getArraySize(Object) - Method in class org.apache.avro.generic.GenericDatumWriter
Called by the default implementation of GenericDatumWriter.writeArray(org.apache.avro.Schema, java.lang.Object, org.apache.avro.io.Encoder) to get the size of an array.
getAverageBytes(List<Long>) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getAverageTime(List<TraceCollection.TraceTiming>) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
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.
getBeginColumn() - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
getBeginLine() - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
getBlockCount() - Method in class org.apache.avro.file.DataFileStream
Expert: Return the count of items in the current block.
getBlockSize() - Method in class org.apache.avro.io.EncoderFactory
Returns this factory's configured default block buffer size.
getBlockSizeBytes() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the desired size of the file blocks.
getBoolean(String) - Method in class org.apache.trevni.MetaData
Return true iff a key has any value, false if it is not present.
getBufferList() - Method in class org.apache.avro.util.ByteBufferOutputStream
Returns all data written and resets the stream to be empty.
getBufferSize() - Method in class org.apache.avro.io.EncoderFactory
Returns this factory's configured default buffer size.
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.
getByteLength() - Method in class org.apache.avro.util.Utf8
Return length in bytes.
getBytes() - Method in class org.apache.avro.util.Utf8
Return UTF-8 encoded bytes.
getBytesFor(String) - Static method in class org.apache.avro.util.Utf8
Gets the UTF-8 bytes for a String
getCause() - Method in interface org.apache.avro.data.ErrorBuilder
Gets the error cause
getCause() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
getCharts() - Method in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
 
getChecksum() - Method in class org.apache.trevni.MetaData
Return the checksum algorithm name.
getChildren() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getChildren() - Method in class org.apache.avro.ipc.trace.TraceNode
Return the children of this node.
getChildren() - Method in class org.apache.trevni.ColumnMetaData
Return this column's children or null.
getClass(Schema) - Method in class org.apache.avro.reflect.ReflectData
 
getClass(Schema) - Method in class org.apache.avro.specific.SpecificData
Return the class that implements a schema, or null if none exists.
getClassLoader() - Method in class org.apache.avro.generic.GenericData
Return the class loader that's used (by subclasses).
getClassName(Schema) - Static method in class org.apache.avro.specific.SpecificData
Returns the Java class name indicated by a schema's name and namespace.
getClassSchema() - Static method in enum org.apache.avro.ipc.HandshakeMatch
 
getClassSchema() - Static method in class org.apache.avro.ipc.HandshakeRequest
 
getClassSchema() - Static method in class org.apache.avro.ipc.HandshakeResponse
 
getClassSchema() - Static method in class org.apache.avro.ipc.MD5
 
getClassSchema() - Static method in class org.apache.avro.ipc.trace.ID
 
getClassSchema() - Static method in class org.apache.avro.ipc.trace.Span
 
getClassSchema() - Static method in enum org.apache.avro.ipc.trace.SpanEvent
 
getClassSchema() - Static method in class org.apache.avro.ipc.trace.TimestampedEvent
 
getClassSchema() - Static method in enum org.apache.avro.mapred.tether.TaskType
 
getClient(Class<T>, Transceiver) - Static method in class org.apache.avro.ipc.reflect.ReflectRequestor
Create a proxy instance whose methods invoke RPCs.
getClient(Class<T>, Transceiver, ReflectData) - Static method in class org.apache.avro.ipc.reflect.ReflectRequestor
Create a proxy instance whose methods invoke RPCs.
getClient(Class<T>, ReflectRequestor) - Static method in class org.apache.avro.ipc.reflect.ReflectRequestor
Create a proxy instance whose methods invoke RPCs.
getClient(Class<T>, Transceiver) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
Create a proxy instance whose methods invoke RPCs.
getClient(Class<T>, Transceiver, SpecificData) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
Create a proxy instance whose methods invoke RPCs.
getClient(Class<T>, SpecificRequestor) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
Create a proxy instance whose methods invoke RPCs.
getClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Gets the value of the 'clientHash' field
getClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest
Gets the value of the 'clientHash' field.
getClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Gets the value of the 'clientProtocol' field
getClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest
Gets the value of the 'clientProtocol' field.
getCodec() - Method in class org.apache.trevni.MetaData
Return the compression codec name.
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.
getColumn() - Method in class org.apache.avro.compiler.idl.JavaCharStream
Deprecated.
getColumnCount() - Method in class org.apache.trevni.ColumnFileReader
Return the number of columns in this file.
getColumnCount() - Method in class org.apache.trevni.ColumnFileWriter
Return the number of columns in the file.
getColumnMetaData() - Method in class org.apache.trevni.ColumnFileReader
Return all columns' metadata.
getColumnMetaData(int) - Method in class org.apache.trevni.ColumnFileReader
Return a column's metadata.
getColumnMetaData(String) - Method in class org.apache.trevni.ColumnFileReader
Return a column's metadata.
getComplete() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'complete' field
getComplete() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'complete' field.
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.
getComputeTime() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceTiming
 
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.
getConfiguredBufferSize() - Method in class org.apache.avro.io.DecoderFactory
Returns this factory's configured preferred buffer size.
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
getCurrentKey() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordReader
getCurrentKey() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordReader
getCurrentRecord() - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
Gets the current record read from the Avro container file.
getCurrentRecord() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
Gets the current record read from the Trevni 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
getCurrentValue() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordReader
getCurrentValue() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordReader
getData() - Method in class org.apache.avro.generic.GenericDatumReader
Return the GenericData implementation.
getData() - Method in class org.apache.avro.generic.GenericDatumWriter
Return the GenericData implementation.
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/seralization.
getDataModelClass(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
Return the job's data model implementation class.
getDatas() - Method in class org.apache.avro.ipc.NettyTransportCodec.NettyDataPack
 
getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.generic.GenericResponder
 
getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.reflect.ReflectRequestor
 
getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.reflect.ReflectResponder
 
getDatumReader(Schema) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
Deprecated.
getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
 
getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.specific.SpecificResponder
 
getDatumWriter(Schema) - Method in class org.apache.avro.ipc.generic.GenericResponder
 
getDatumWriter(Schema) - Method in class org.apache.avro.ipc.reflect.ReflectRequestor
 
getDatumWriter(Schema) - Method in class org.apache.avro.ipc.reflect.ReflectResponder
 
getDatumWriter(Schema) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
 
getDatumWriter(Schema) - Method in class org.apache.avro.ipc.specific.SpecificResponder
 
getDefaultValue(Schema.Field) - Method in class org.apache.avro.generic.GenericData
Gets the default value of the given field, if any.
getDescription() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
Gets a human readable description of this validation result.
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.
getDoc() - Method in class org.apache.avro.Protocol
Doc string for this protocol.
getDoc() - Method in class org.apache.avro.Protocol.Message
 
getDoc() - Method in class org.apache.avro.Schema
If this is a record, enum, or fixed, returns its docstring, if available.
getElementType() - Method in class org.apache.avro.Schema
If this is an array, returns its element type.
getEndColumn() - Method in class org.apache.avro.compiler.idl.JavaCharStream
Get end column.
getEndLine() - Method in class org.apache.avro.compiler.idl.JavaCharStream
Get end line.
getEnumOrdinal(String) - Method in class org.apache.avro.Schema
If this is an enum, return a symbol's ordinal value.
getEnumSchema(Object) - Method in class org.apache.avro.generic.GenericData
Called to obtain the schema of a enum.
getEnumSchema(Object) - Method in class org.apache.avro.specific.SpecificData
 
getEnumSchema(Object) - Method in class org.apache.avro.thrift.ThriftData
 
getEnumSymbols() - Method in class org.apache.avro.Schema
If this is an enum, return its symbols.
getError() - Method in class org.apache.avro.ipc.CallFuture
Gets the error that was thrown during RPC execution.
getErrors() - Method in class org.apache.avro.Protocol.Message
Errors that might be thrown.
getEvent() - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Gets the value of the 'event' field
getEvent() - Method in class org.apache.avro.ipc.trace.TimestampedEvent
Gets the value of the 'event' field.
getEvents() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'events' field
getEvents() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'events' field.
getExecutable(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
Get the URI of the application's executable.
getExecutionPathHash() - Method in class org.apache.avro.ipc.trace.TraceCollection
 
getExpected() - Method in class org.apache.avro.generic.GenericDatumReader
Get the reader's schema.
getField(Object, String, int) - Method in class org.apache.avro.generic.GenericData
getField(Object, String, int, Object) - Method in class org.apache.avro.generic.GenericData
getField(Object, String, int) - Method in class org.apache.avro.protobuf.ProtobufData
 
getField(Object, String, int, Object) - Method in class org.apache.avro.protobuf.ProtobufData
 
getField(Object, String, int) - Method in class org.apache.avro.reflect.ReflectData
 
getField(Object, String, int, Object) - Method in class org.apache.avro.reflect.ReflectData
 
getField(String) - Method in class org.apache.avro.Schema
If this is a record, returns the Field with the given name fieldName.
getField(Object, String, int) - Method in class org.apache.avro.thrift.ThriftData
 
getField(Object, String, int, Object) - Method in class org.apache.avro.thrift.ThriftData
 
getFields() - Method in class org.apache.avro.Schema
If this is a record, returns the fields in it.
getFieldVisibility() - Method in class org.apache.avro.mojo.AbstractAvroMojo
 
getFileSchema() - Method in class org.apache.trevni.avro.AvroColumnReader
Return the schema for data in this file.
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.
getFixedSchema(Object) - Method in class org.apache.avro.generic.GenericData
Called to obtain the schema of a fixed.
getFixedSize() - Method in class org.apache.avro.Schema
If this is fixed, returns its size.
getFullName() - Method in class org.apache.avro.Schema
If this is a record, enum or fixed, returns its namespace-qualified name, otherwise returns the name of the primitive type.
getGenericData() - Method in class org.apache.avro.ipc.generic.GenericRequestor
 
getGenericData() - Method in class org.apache.avro.ipc.generic.GenericResponder
 
getHandshakeRequest() - Method in class org.apache.avro.ipc.RPCContext
Get the handshake request of this RPC.
getHandshakeResponse() - Method in class org.apache.avro.ipc.RPCContext
Get the handshake response of this RPC.
getHeader() - Method in class org.apache.avro.file.DataFileStream
A handle that can be used to reopen this stream without rereading the head.
GetImage() - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
getIncludes() - Method in class org.apache.avro.mojo.AbstractAvroMojo
 
getIncludes() - Method in class org.apache.avro.mojo.IDLProtocolMojo
 
getIncludes() - Method in class org.apache.avro.mojo.ProtocolMojo
 
getIncludes() - Method in class org.apache.avro.mojo.SchemaMojo
 
getIndexInterval() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
Gets the index interval.
getIndexNamed(String) - Method in class org.apache.avro.Schema
If this is a union, return the branch with the provided full name.
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.
getJsonProp(String) - Method in class org.apache.avro.JsonProperties
Returns the value of the named property in this schema.
getJsonProps() - Method in class org.apache.avro.JsonProperties
Return the defined properties as an unmodifieable Map.
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.
getLabel(int) - Method in class org.apache.avro.io.parsing.Symbol.Alternative
 
getLabel(int) - Method in class org.apache.avro.io.parsing.Symbol.EnumLabelsAction
 
getLatencyTimeString() - Method in class org.apache.avro.ipc.trace.TraceNode
 
getLength() - Method in class org.apache.avro.util.Utf8
Deprecated.
call Utf8.getByteLength() instead.
getLine() - Method in class org.apache.avro.compiler.idl.JavaCharStream
Deprecated.
getLocal() - Method in class org.apache.avro.ipc.Requestor
 
getLocal() - Method in class org.apache.avro.ipc.Responder
Return the local protocol.
getLong(String) - Method in class org.apache.trevni.MetaData
Return the value of a metadata property as a long.
getMapEntries(Object) - Method in class org.apache.avro.generic.GenericDatumWriter
Called by the default implementation of GenericDatumWriter.writeMap(org.apache.avro.Schema, java.lang.Object, org.apache.avro.io.Encoder) to enumerate map elements.
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.
getMapSize(Object) - Method in class org.apache.avro.generic.GenericDatumWriter
Called by the default implementation of GenericDatumWriter.writeMap(org.apache.avro.Schema, java.lang.Object, org.apache.avro.io.Encoder) to get the size of a map.
getMatch() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Gets the value of the 'match' field
getMatch() - Method in class org.apache.avro.ipc.HandshakeResponse
Gets the value of the 'match' field.
getMaxBytes(List<Long>) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getMaxTime(List<TraceCollection.TraceTiming>) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getMD5() - Method in class org.apache.avro.Protocol
Return the MD5 hash of the text of this protocol.
getMessage() - Method in error org.apache.avro.compiler.idl.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessage() - Method in class org.apache.avro.ipc.RPCContext
Returns the Protocol.Message corresponding to this RPC
getMessageName() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'messageName' field
getMessageName() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'messageName' field.
getMessageName() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getMessageName() - Method in class org.apache.avro.ipc.trace.TraceNode
 
getMessages() - Method in class org.apache.avro.Protocol
The messages of this protocol.
getMeta(String) - Method in class org.apache.avro.file.DataFileReader12
Return the value of a metadata property.
getMeta(String) - Method in class org.apache.avro.file.DataFileStream
Return the value of a metadata property.
getMeta() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Gets the value of the 'meta' field
getMeta() - Method in class org.apache.avro.ipc.HandshakeRequest
Gets the value of the 'meta' field.
getMeta() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Gets the value of the 'meta' field
getMeta() - Method in class org.apache.avro.ipc.HandshakeResponse
Gets the value of the 'meta' field.
getMetadata() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the SequenceFile metadata to store in the header.
getMetaData() - Method in class org.apache.trevni.ColumnFileReader
Return this file's metadata.
getMetaData() - Method in class org.apache.trevni.ColumnFileWriter
Return this file's metadata.
getMetaKeys() - Method in class org.apache.avro.file.DataFileStream
Return the list of keys in the metadata
getMetaLong(String) - Method in class org.apache.avro.file.DataFileReader12
Return the value of a metadata property.
getMetaLong(String) - Method in class org.apache.avro.file.DataFileStream
Return the value of a metadata property.
getMetaString(String) - Method in class org.apache.avro.file.DataFileReader12
Return the value of a metadata property.
getMetaString(String) - Method in class org.apache.avro.file.DataFileStream
Return the value of a metadata property.
getMinBytes(List<Long>) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getMinTime(List<TraceCollection.TraceTiming>) - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getName() - Method in class org.apache.avro.file.BZip2Codec
 
getName() - Method in class org.apache.avro.file.Codec
Name of the codec; written to the file's metadata.
getName() - Method in class org.apache.avro.file.XZCodec
 
getname() - Method in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
 
getName() - Method in class org.apache.avro.Protocol
The name of this protocol.
getName() - Method in class org.apache.avro.Protocol.Message
The name of this message.
getName() - Method in class org.apache.avro.Schema
If this is a record, enum or fixed, returns its name, otherwise the name of the primitive type.
getName() - Method in enum org.apache.avro.Schema.Type
 
getName() - Method in class org.apache.avro.tool.BinaryFragmentToJsonTool
 
getName() - Method in class org.apache.avro.tool.CatTool
 
getName() - Method in class org.apache.avro.tool.ConcatTool
 
getName() - Method in class org.apache.avro.tool.CreateRandomFileTool
 
getName() - Method in class org.apache.avro.tool.DataFileGetMetaTool
 
getName() - Method in class org.apache.avro.tool.DataFileGetSchemaTool
 
getName() - Method in class org.apache.avro.tool.DataFileReadTool
 
getName() - Method in class org.apache.avro.tool.DataFileWriteTool
 
getName() - Method in class org.apache.avro.tool.FromTextTool
 
getName() - Method in class org.apache.avro.tool.IdlTool
 
getName() - Method in class org.apache.avro.tool.IdlToSchemataTool
 
getName() - Method in class org.apache.avro.tool.InduceSchemaTool
 
getName() - Method in class org.apache.avro.tool.JsonToBinaryFragmentTool
 
getName() - Method in class org.apache.avro.tool.RecodecTool
 
getName() - Method in class org.apache.avro.tool.RpcProtocolTool
 
getName() - Method in class org.apache.avro.tool.RpcReceiveTool
 
getName() - Method in class org.apache.avro.tool.RpcSendTool
 
getName() - Method in class org.apache.avro.tool.SpecificCompilerTool
 
getName() - Method in class org.apache.avro.tool.TetherTool
 
getName() - Method in interface org.apache.avro.tool.Tool
Name of tool, to be used in listings.
getName() - Method in class org.apache.avro.tool.ToTextTool
 
getName() - Method in class org.apache.avro.tool.ToTrevniTool
 
getName() - Method in class org.apache.avro.tool.TrevniCreateRandomTool
 
getName() - Method in class org.apache.avro.tool.TrevniMetadataTool
 
getName() - Method in class org.apache.avro.tool.TrevniToJsonTool
 
getName() - Method in class org.apache.trevni.ColumnMetaData
Return this column's name.
getName() - Method in enum org.apache.trevni.ValueType
Return the name of this type.
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.
getNamespace() - Method in class org.apache.avro.Protocol
The namespace of this protocol.
getNamespace() - Method in class org.apache.avro.Schema
If this is a record, enum or fixed, returns its namespace, if any.
getNextToken() - Method in class org.apache.avro.compiler.idl.Idl
Get the next Token.
getNextToken() - Method in class org.apache.avro.compiler.idl.IdlTokenManager
Get the next Token.
getNodeWithID(int) - Method in class org.apache.avro.ipc.trace.TraceCollection
 
getNodeWithIDRecurse(int, TraceCollection.TraceNodeStats) - Method in class org.apache.avro.ipc.trace.TraceCollection
 
getNumActiveConnections() - Method in class org.apache.avro.ipc.NettyServer
 
getNumber() - Method in class org.apache.trevni.ColumnMetaData
Return this column's number in a file.
getNumCalls() - Method in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
 
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.
getParent() - Method in class org.apache.trevni.ColumnMetaData
Return this column's parent or null.
getParentSpanID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'parentSpanID' field
getParentSpanID() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'parentSpanID' field.
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.
getPort() - Method in class org.apache.avro.ipc.DatagramServer
 
getPort() - Method in class org.apache.avro.ipc.HttpServer
 
getPort() - Method in class org.apache.avro.ipc.NettyServer
 
getPort() - Method in interface org.apache.avro.ipc.Server
The port this server runs on.
getPort() - Method in class org.apache.avro.ipc.SocketServer
Deprecated.
 
getPos() - Method in class org.apache.avro.mapred.AvroRecordReader
 
getPostLinkTime() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceTiming
 
getPostLinkTime() - Method in class org.apache.avro.ipc.trace.TraceNode
Return time delta between { @link SpanEvent.SERVER_SEND } and { @link SpanEvent.CLIENT_RECV }.
getPostLinkTimeString() - Method in class org.apache.avro.ipc.trace.TraceNode
Return post-link time as a string.
getPreLinkTime() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceTiming
 
getPreLinkTime() - Method in class org.apache.avro.ipc.trace.TraceNode
Return time delta between { @link SpanEvent.CLIENT_SEND } and { @link SpanEvent.SERVER_RECV }.
getPreLinkTimeString() - Method in class org.apache.avro.ipc.trace.TraceNode
Return pre-link time as a string.
getProcessTime() - Method in class org.apache.avro.ipc.trace.TraceNode
Return time delta between { @link SpanEvent.SERVER_RECV } and { @link SpanEvent.SERVER_SEND}.
getProcessTimeString() - Method in class org.apache.avro.ipc.trace.TraceNode
Return cpu time as a string.
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
getProgress() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
getProgressable() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
Gets the object to report progress to.
getProp(String) - Method in class org.apache.avro.JsonProperties
Returns the value of the named, string-valued property in this schema.
getProps() - Method in class org.apache.avro.JsonProperties
Deprecated.
getProtocol(Class) - Method in class org.apache.avro.reflect.ReflectData
Return the protocol for a Java interface.
getProtocol(Class) - Method in class org.apache.avro.specific.SpecificData
Return the protocol for a Java interface.
getReader() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
Gets the reader schema that was validated.
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
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.trevni.avro.AvroTrevniInputFormat
 
getRecordSchema(Object) - Method in class org.apache.avro.generic.GenericData
Called to obtain the schema of a record.
getRecordSchema(Object) - Method in class org.apache.avro.protobuf.ProtobufData
 
getRecordSchema(Object) - Method in class org.apache.avro.reflect.ReflectData
 
getRecordSchema(Object) - Method in class org.apache.avro.thrift.ThriftData
 
getRecordState(Object, Schema) - Method in class org.apache.avro.generic.GenericData
getRecordState(Object, Schema) - Method in class org.apache.avro.protobuf.ProtobufData
 
getRecordState(Object, Schema) - Method in class org.apache.avro.reflect.ReflectData
 
getRecordState(Object, Schema) - Method in class org.apache.avro.thrift.ThriftData
 
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
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.trevni.avro.AvroTrevniOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueOutputFormat
getReflectData() - Method in class org.apache.avro.ipc.reflect.ReflectRequestor
 
getReflectData() - Method in class org.apache.avro.ipc.reflect.ReflectResponder
 
getRemote() - Method in class org.apache.avro.ipc.NettyTransceiver
 
getRemote() - Method in class org.apache.avro.ipc.Requestor
Return the remote protocol.
getRemote() - Static method in class org.apache.avro.ipc.Responder
Return the remote protocol.
getRemote() - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
getRemote() - Method in class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
getRemote(Object) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
Return the remote protocol for a proxy.
getRemote() - Method in class org.apache.avro.ipc.Transceiver
Returns the protocol passed to Transceiver.setRemote(Protocol).
getRemoteName() - Method in class org.apache.avro.ipc.DatagramTransceiver
 
getRemoteName() - Method in class org.apache.avro.ipc.HttpTransceiver
 
getRemoteName() - Method in class org.apache.avro.ipc.LocalTransceiver
 
getRemoteName() - Method in class org.apache.avro.ipc.NettyTransceiver
 
getRemoteName() - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
getRemoteName() - Method in class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
getRemoteName() - Method in class org.apache.avro.ipc.Transceiver
 
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.
getRequest() - Method in class org.apache.avro.Protocol.Message
The parameters of this message.
getRequestorHostname() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'requestorHostname' field
getRequestorHostname() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'requestorHostname' field.
getRequestorHostname() - Method in class org.apache.avro.ipc.trace.TraceNode
 
getRequestPayload() - Method in class org.apache.avro.ipc.RPCContext
Returns the serialized payload of the request in this RPC.
getRequestPayloads() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getRequestPayloadSize() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'requestPayloadSize' field
getRequestPayloadSize() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'requestPayloadSize' field.
getRequestPayloadSize() - Method in class org.apache.avro.ipc.trace.TraceNode
 
getResolver(Schema, Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Gets a resolving decoder for use by this GenericDatumReader.
getResource(String) - Method in class org.apache.avro.ipc.stats.StaticServlet
 
getResource(String) - Method in class org.apache.avro.ipc.trace.StaticServlet
 
getResponderHostname() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'responderHostname' field
getResponderHostname() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'responderHostname' field.
getResponderHostname() - Method in class org.apache.avro.ipc.trace.TraceNode
 
getResponse() - Method in class org.apache.avro.Protocol.Message
The returned data.
getResponsePayload() - Method in class org.apache.avro.ipc.RPCContext
Returns the serialized payload of the response in this RPC.
getResponsePayloads() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getResponsePayloadSize() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'responsePayloadSize' field
getResponsePayloadSize() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'responsePayloadSize' field.
getResponsePayloadSize() - Method in class org.apache.avro.ipc.trace.TraceNode
 
getResult() - Method in class org.apache.avro.ipc.CallFuture
Gets the value of the RPC result without blocking.
getRoot() - Method in class org.apache.avro.ipc.trace.Trace
Return the root node of this trace.
getRootNode() - Method in class org.apache.avro.ipc.trace.TraceCollection
 
getRoots() - Method in class org.apache.trevni.ColumnFileReader
Return root columns' metadata.
getRow() - Method in class org.apache.trevni.ColumnValues
Return the current row number within this file.
getRowCount() - Method in class org.apache.trevni.avro.AvroColumnReader
Return the number of rows in this file.
getRowCount() - Method in class org.apache.trevni.ColumnFileReader
Return the number of rows in this file.
getSchema() - Method in class org.apache.avro.file.DataFileReader12
Return the schema used in this file.
getSchema() - Method in class org.apache.avro.file.DataFileStream
Return the schema used in this file.
getSchema() - Method in interface org.apache.avro.file.FileReader
Return the schema for data in this file.
getSchema() - Method in interface org.apache.avro.generic.GenericContainer
The schema of this instance.
getSchema() - Method in class org.apache.avro.generic.GenericData.Array
 
getSchema() - Method in class org.apache.avro.generic.GenericData.EnumSymbol
 
getSchema() - Method in class org.apache.avro.generic.GenericData.Fixed
 
getSchema() - Method in class org.apache.avro.generic.GenericData.Record
 
getSchema() - Method in class org.apache.avro.generic.GenericDatumReader
Return the writer's schema.
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.ipc.HandshakeRequest
 
getSchema() - Method in class org.apache.avro.ipc.HandshakeResponse
 
getSchema() - Method in class org.apache.avro.ipc.trace.Span
 
getSchema() - Method in class org.apache.avro.ipc.trace.TimestampedEvent
 
getSchema() - Method in class org.apache.avro.mapred.Pair
 
getSchema() - Method in class org.apache.avro.mapred.SequenceFileReader
 
getSchema(Class) - Method in class org.apache.avro.protobuf.ProtobufData
Return a record schema given a protobuf message class.
getSchema() - Method in class org.apache.avro.reflect.CustomEncoding
 
getSchema(Type) - Method in class org.apache.avro.specific.SpecificData
Find the schema for a Java type.
getSchema() - Method in exception org.apache.avro.specific.SpecificExceptionBase
 
getSchema() - Method in class org.apache.avro.specific.SpecificRecordBase
 
getSchema(Class) - Method in class org.apache.avro.thrift.ThriftData
Return a record schema given a thrift generated class.
getSchemaName(Object) - Method in class org.apache.avro.generic.GenericData
Return the schema full name for a datum.
getSchemaName(Object) - Method in class org.apache.avro.specific.SpecificData
 
getSerial() - Method in class org.apache.avro.ipc.NettyTransportCodec.NettyDataPack
 
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.
getServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Gets the value of the 'serverHash' field
getServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest
Gets the value of the 'serverHash' field.
getServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Gets the value of the 'serverHash' field
getServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse
Gets the value of the 'serverHash' field.
getServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Gets the value of the 'serverProtocol' field
getServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse
Gets the value of the 'serverProtocol' field.
getShortDescription() - Method in class org.apache.avro.tool.BinaryFragmentToJsonTool
 
getShortDescription() - Method in class org.apache.avro.tool.CatTool
 
getShortDescription() - Method in class org.apache.avro.tool.ConcatTool
 
getShortDescription() - Method in class org.apache.avro.tool.CreateRandomFileTool
 
getShortDescription() - Method in class org.apache.avro.tool.DataFileGetMetaTool
 
getShortDescription() - Method in class org.apache.avro.tool.DataFileGetSchemaTool
 
getShortDescription() - Method in class org.apache.avro.tool.DataFileReadTool
 
getShortDescription() - Method in class org.apache.avro.tool.DataFileWriteTool
 
getShortDescription() - Method in class org.apache.avro.tool.FromTextTool
 
getShortDescription() - Method in class org.apache.avro.tool.IdlTool
 
getShortDescription() - Method in class org.apache.avro.tool.IdlToSchemataTool
 
getShortDescription() - Method in class org.apache.avro.tool.InduceSchemaTool
 
getShortDescription() - Method in class org.apache.avro.tool.JsonToBinaryFragmentTool
 
getShortDescription() - Method in class org.apache.avro.tool.RecodecTool
 
getShortDescription() - Method in class org.apache.avro.tool.RpcProtocolTool
 
getShortDescription() - Method in class org.apache.avro.tool.RpcReceiveTool
 
getShortDescription() - Method in class org.apache.avro.tool.RpcSendTool
 
getShortDescription() - Method in class org.apache.avro.tool.SpecificCompilerTool
 
getShortDescription() - Method in class org.apache.avro.tool.TetherTool
 
getShortDescription() - Method in interface org.apache.avro.tool.Tool
1-line description to be used in command listings.
getShortDescription() - Method in class org.apache.avro.tool.ToTextTool
 
getShortDescription() - Method in class org.apache.avro.tool.ToTrevniTool
 
getShortDescription() - Method in class org.apache.avro.tool.TrevniCreateRandomTool
 
getShortDescription() - Method in class org.apache.avro.tool.TrevniMetadataTool
 
getShortDescription() - Method in class org.apache.avro.tool.TrevniToJsonTool
 
getSingleton() - Static method in class org.apache.avro.ipc.trace.TracePlugin
Get a singleton TracePlugin.
getSpanID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'spanID' field
getSpanID() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'spanID' field.
getSpansInRange(long, long, Callback<List<Span>>) - Method in interface org.apache.avro.ipc.trace.AvroTrace.Callback
Get spans occuring between start and end.
getSpansInRange(long, long) - Method in interface org.apache.avro.ipc.trace.AvroTrace
Get spans occuring between start and end.
getSpansInRange(long, long) - Method in class org.apache.avro.ipc.trace.FileSpanStorage
 
getSpansInRange(long, long) - Method in class org.apache.avro.ipc.trace.InMemorySpanStorage
 
getSpansInRange(long, long) - Method in interface org.apache.avro.ipc.trace.SpanStorage
Return a list of all spans that fall within the time given range.
getSpecificData() - Method in class org.apache.avro.ipc.specific.SpecificRequestor
 
getSpecificData() - Method in class org.apache.avro.ipc.specific.SpecificResponder
 
getSpecificData() - Method in class org.apache.avro.specific.SpecificDatumReader
Return the contained SpecificData.
getSpecificData() - Method in class org.apache.avro.specific.SpecificDatumWriter
Returns the SpecificData implementation used by this writer.
getString(String) - Method in class org.apache.trevni.MetaData
Return the value of a metadata property as a String.
getStringType() - Method in class org.apache.avro.compiler.specific.ProtocolTask
Get the string type.
GetSuffix(int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
getSymbol(int) - Method in class org.apache.avro.io.parsing.Symbol.Alternative
 
getSyncInterval(TaskAttemptContext) - Static method in class org.apache.avro.mapreduce.AvroOutputFormatBase
Gets the configured sync interval from the task context.
getTabSize(int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
getTemplate(VelocityEngine, String) - Static method in class org.apache.avro.ipc.trace.TraceClientServlet
 
getTestIncludes() - Method in class org.apache.avro.mojo.AbstractAvroMojo
 
getTestIncludes() - Method in class org.apache.avro.mojo.IDLProtocolMojo
 
getTestIncludes() - Method in class org.apache.avro.mojo.ProtocolMojo
 
getTestIncludes() - Method in class org.apache.avro.mojo.SchemaMojo
 
getTimeStamp() - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Gets the value of the 'timeStamp' field
getTimeStamp() - Method in class org.apache.avro.ipc.trace.TimestampedEvent
Gets the value of the 'timeStamp' field.
getToken(int) - Method in class org.apache.avro.compiler.idl.Idl
Get the specific Token.
getTotalTime() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceTiming
 
getTraceID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Gets the value of the 'traceID' field
getTraceID() - Method in class org.apache.avro.ipc.trace.Span
Gets the value of the 'traceID' field.
getTraces() - Method in class org.apache.avro.ipc.trace.TraceCollection
 
getTraceTimings() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getTraceTimingsSorted() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
getTransceiver() - Method in class org.apache.avro.ipc.Requestor
 
getTransceiver(SocketChannel) - Method in class org.apache.avro.ipc.SaslSocketServer
 
getTransceiver(SocketChannel) - Method in class org.apache.avro.ipc.SocketServer
Deprecated.
Creates an appropriate Transceiver for this server.
getType(String) - Method in class org.apache.avro.Protocol
Returns the named type.
getType() - Method in class org.apache.avro.Schema
Return the type of this schema.
getType() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
Gets the type of this result.
getType() - Method in class org.apache.trevni.ColumnMetaData
Return this column's type.
getTypes() - Method in class org.apache.avro.Protocol
The types of this protocol.
getTypes() - Method in class org.apache.avro.Schema
If this is a union, returns its types.
getTypes() - Method in class org.apache.avro.Schema.Parser
Returns the set of defined, named types known to this parser.
getUnionSchema() - Method in exception org.apache.avro.UnresolvedUnionException
 
getUnresolvedDatum() - Method in exception org.apache.avro.UnresolvedUnionException
 
getValidate() - Method in class org.apache.avro.Schema.Parser
True iff names are validated.
getValue() - Method in exception org.apache.avro.AvroRemoteException
 
getValue() - Method in class org.apache.avro.compiler.idl.Token
An optional attribute value of the Token.
getValue() - Method in interface org.apache.avro.data.ErrorBuilder
Gets the value
getValue() - Method in class org.apache.avro.hadoop.io.AvroKeyValue
Read the value.
getValue() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
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.
getValues(String) - Method in class org.apache.trevni.ColumnFileReader
Return an iterator over values in the named column.
getValues(int) - Method in class org.apache.trevni.ColumnFileReader
Return an iterator over values in a column.
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.
getValueType() - Method in class org.apache.avro.Schema
If this is a map, returns its value type.
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.
getWriter() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
Gets the writer schema that was validated.
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.
GT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.

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
 
HadoopInput - Class in org.apache.trevni.avro
Adapt a Hadoop FSDataInputStream to Trevni's Input.
HadoopInput(Path, Configuration) - Constructor for class org.apache.trevni.avro.HadoopInput
Construct given a path and a configuration.
handleError(Throwable) - Method in interface org.apache.avro.ipc.Callback
Receives an error.
handleError(Throwable) - Method in class org.apache.avro.ipc.CallFuture
Sets an error thrown during RPC execution, and unblocks all threads waiting on CallFuture.get() or CallFuture.get(long, TimeUnit).
handleError(Throwable) - Method in class org.apache.avro.ipc.Requestor.TransceiverCallback
 
handleResult(T) - Method in interface org.apache.avro.ipc.Callback
Receives a callback result.
handleResult(T) - Method in class org.apache.avro.ipc.CallFuture
Sets the RPC response, and unblocks all threads waiting on CallFuture.get() or CallFuture.get(long, TimeUnit).
handleResult(List<ByteBuffer>) - Method in class org.apache.avro.ipc.Requestor.TransceiverCallback
 
handleUpstream(ChannelHandlerContext, ChannelEvent) - Method in class org.apache.avro.ipc.NettyTransceiver.NettyClientAvroHandler
 
HandshakeMatch - Enum in org.apache.avro.ipc
 
HandshakeRequest - Class in org.apache.avro.ipc
 
HandshakeRequest() - Constructor for class org.apache.avro.ipc.HandshakeRequest
Default constructor.
HandshakeRequest(MD5, String, MD5, Map<String, ByteBuffer>) - Constructor for class org.apache.avro.ipc.HandshakeRequest
All-args constructor.
HandshakeRequest.Builder - Class in org.apache.avro.ipc
RecordBuilder for HandshakeRequest instances.
HandshakeResponse - Class in org.apache.avro.ipc
 
HandshakeResponse() - Constructor for class org.apache.avro.ipc.HandshakeResponse
Default constructor.
HandshakeResponse(HandshakeMatch, String, MD5, Map<String, ByteBuffer>) - Constructor for class org.apache.avro.ipc.HandshakeResponse
All-args constructor.
HandshakeResponse.Builder - Class in org.apache.avro.ipc
RecordBuilder for HandshakeResponse instances.
has(String) - Method in class org.apache.avro.generic.GenericRecordBuilder
Checks whether a field has been set.
has(Schema.Field) - Method in class org.apache.avro.generic.GenericRecordBuilder
Checks whether a field has been set.
has(int) - Method in class org.apache.avro.generic.GenericRecordBuilder
Checks whether a field has been set.
hasCause() - Method in interface org.apache.avro.data.ErrorBuilder
Checks whether the cause has been set
hasCause() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
hasClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Checks whether the 'clientHash' field has been set
hasClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Checks whether the 'clientProtocol' field has been set
hasComplete() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'complete' field has been set
hasEnumSymbol(String) - Method in class org.apache.avro.Schema
If this is an enum, returns true if it contains given symbol.
hasEvent() - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Checks whether the 'event' field has been set
hasEvents() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'events' field has been set
hashCode() - Method in class org.apache.avro.data.RecordBuilderBase
 
hashCode() - Method in class org.apache.avro.file.BZip2Codec
 
hashCode() - Method in class org.apache.avro.file.Codec
Codecs must implement a hashCode() method that is consistent with equals().
hashCode() - Method in class org.apache.avro.file.XZCodec
 
hashCode() - Method in class org.apache.avro.generic.GenericData.EnumSymbol
 
hashCode() - Method in class org.apache.avro.generic.GenericData.Fixed
 
hashCode(Object, Schema) - Method in class org.apache.avro.generic.GenericData
Compute a hash code according to a schema, consistent with GenericData.compare(Object,Object,Schema).
hashCode() - Method in class org.apache.avro.generic.GenericData.Record
 
hashCode() - Method in class org.apache.avro.generic.GenericRecordBuilder
 
hashCode(byte[], int, int, Schema) - Static method in class org.apache.avro.io.BinaryData
Hash binary encoded data.
hashCode() - Method in class org.apache.avro.mapred.AvroWrapper
 
hashCode() - Method in class org.apache.avro.mapred.Pair
 
hashCode() - Method in class org.apache.avro.Protocol
 
hashCode() - Method in class org.apache.avro.Protocol.Message
 
hashCode() - Method in class org.apache.avro.Schema.Field
 
hashCode() - Method in class org.apache.avro.Schema
 
hashCode() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
hashCode() - Method in exception org.apache.avro.specific.SpecificExceptionBase
 
hashCode() - Method in class org.apache.avro.specific.SpecificRecordBase
 
hashCode() - Method in class org.apache.avro.util.Utf8
 
hashCode() - Method in class org.apache.avro.util.WeakIdentityHashMap
 
hashCodeAdd(int, Object, Schema) - Method in class org.apache.avro.generic.GenericData
Add the hash code for an object into an accumulated hash code.
hasIndexValues(boolean) - Method in class org.apache.trevni.ColumnMetaData
Set whether this column has an index of blocks by value.
hasIndexValues() - Method in class org.apache.trevni.ColumnMetaData
Get whether this column has an index of blocks by value.
hasMatch() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Checks whether the 'match' field has been set
hasMessageName() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'messageName' field has been set
hasMeta() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Checks whether the 'meta' field has been set
hasMeta() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Checks whether the 'meta' field has been set
hasNext() - Method in class org.apache.avro.file.DataFileReader12
 
hasNext() - Method in class org.apache.avro.file.DataFileStream
True if more entries remain in this file.
hasNext() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
hasNext() - Method in class org.apache.avro.mapred.SequenceFileReader
 
hasNext() - Method in class org.apache.trevni.avro.AvroColumnReader
 
hasNext() - Method in class org.apache.trevni.ColumnValues
 
hasParentSpanID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'parentSpanID' field has been set
hasRequestorHostname() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'requestorHostname' field has been set
hasRequestPayloadSize() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'requestPayloadSize' field has been set
hasResponderHostname() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'responderHostname' field has been set
hasResponsePayloadSize() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'responsePayloadSize' field has been set
hasServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Checks whether the 'serverHash' field has been set
hasServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Checks whether the 'serverHash' field has been set
hasServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Checks whether the 'serverProtocol' field has been set
hasSpanID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'spanID' field has been set
hasTimeStamp() - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Checks whether the 'timeStamp' field has been set
hasTraceID() - Method in class org.apache.avro.ipc.trace.Span.Builder
Checks whether the 'traceID' field has been set
hasValue() - Method in interface org.apache.avro.data.ErrorBuilder
Checks whether the value has been set
hasValue() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
HelpMojo - Class in org.apache.avro.mojo
Display help information on avro-maven-plugin.
Call
HelpMojo() - Constructor for class org.apache.avro.mojo.HelpMojo
 
HEX_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
HEXADECIMAL_EXPONENT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
HEXADECIMAL_FLOATING_POINT_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
HttpServer - Class in org.apache.avro.ipc
An HTTP-based RPC Server.
HttpServer(Responder, int) - Constructor for class org.apache.avro.ipc.HttpServer
Constructs a server to run on the named port.
HttpServer(ResponderServlet, int) - Constructor for class org.apache.avro.ipc.HttpServer
Constructs a server to run on the named port.
HttpServer(Responder, String, int) - Constructor for class org.apache.avro.ipc.HttpServer
Constructs a server to run on the named port on the specified address.
HttpServer(ResponderServlet, String, int) - Constructor for class org.apache.avro.ipc.HttpServer
Constructs a server to run on the named port on the specified address.
HttpServer(Responder, Connector) - Constructor for class org.apache.avro.ipc.HttpServer
Constructs a server to run with the given connector.
HttpServer(ResponderServlet, Connector) - Constructor for class org.apache.avro.ipc.HttpServer
Constructs a server to run with the given connector.
httpServer - Variable in class org.apache.avro.ipc.trace.TracePlugin
 
HttpTransceiver - Class in org.apache.avro.ipc
An HTTP-based Transceiver implementation.
HttpTransceiver(URL) - Constructor for class org.apache.avro.ipc.HttpTransceiver
 
HttpTransceiver(URL, Proxy) - Constructor for class org.apache.avro.ipc.HttpTransceiver
 

I

ID - Class in org.apache.avro.ipc.trace
 
ID() - Constructor for class org.apache.avro.ipc.trace.ID
Creates a new ID
ID(byte[]) - Constructor for class org.apache.avro.ipc.trace.ID
Creates a new ID with the given bytes
Identifier() - Method in class org.apache.avro.compiler.idl.Idl
 
IDENTIFIER - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
Idl - Class in org.apache.avro.compiler.idl
Grammar to parse a higher-level language into an Avro Schema.
Idl(File) - Constructor for class org.apache.avro.compiler.idl.Idl
 
Idl(File, ClassLoader) - Constructor for class org.apache.avro.compiler.idl.Idl
 
Idl(InputStream) - Constructor for class org.apache.avro.compiler.idl.Idl
Constructor with InputStream.
Idl(InputStream, String) - Constructor for class org.apache.avro.compiler.idl.Idl
Constructor with InputStream and supplied encoding
Idl(Reader) - Constructor for class org.apache.avro.compiler.idl.Idl
Constructor.
Idl(IdlTokenManager) - Constructor for class org.apache.avro.compiler.idl.Idl
Constructor with generated Token Manager.
IDL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
IdlConstants - Interface in org.apache.avro.compiler.idl
Token literal values and constants.
IDLProtocolMojo - Class in org.apache.avro.mojo
Generate Java classes and interfaces from AvroIDL files (.avdl)
IDLProtocolMojo() - Constructor for class org.apache.avro.mojo.IDLProtocolMojo
 
IdlTokenManager - Class in org.apache.avro.compiler.idl
Token Manager.
IdlTokenManager(JavaCharStream) - Constructor for class org.apache.avro.compiler.idl.IdlTokenManager
Constructor.
IdlTokenManager(JavaCharStream, int) - Constructor for class org.apache.avro.compiler.idl.IdlTokenManager
Constructor.
IdlTool - Class in org.apache.avro.tool
Tool implementation for generating Avro JSON schemata from idl format files.
IdlTool() - Constructor for class org.apache.avro.tool.IdlTool
 
IdlToSchemataTool - Class in org.apache.avro.tool
Extract the Avro JSON schemata of the types of a protocol defined through an idl format file.
IdlToSchemataTool() - Constructor for class org.apache.avro.tool.IdlToSchemataTool
 
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.
image - Variable in class org.apache.avro.compiler.idl.Token
The string image of the token.
IMPORT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
ImportIdl() - Method in class org.apache.avro.compiler.idl.Idl
 
ImportProtocol() - Method in class org.apache.avro.compiler.idl.Idl
 
imports - Variable in class org.apache.avro.mojo.AbstractAvroMojo
A list of files or directories that should be compiled first thus making them importable by subsequently compiled schemas.
ImportSchema() - Method in class org.apache.avro.compiler.idl.Idl
 
in - Variable in class org.apache.avro.io.ValidatingDecoder
 
inBuf - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
incompleteSpans - Variable in class org.apache.avro.ipc.trace.SpanAggregator.SpanAggregationResults
Spans which have data only from client or server, or in which an ID collision was detected.
INDEX_FILENAME - Static variable in class org.apache.avro.hadoop.file.SortedKeyValueFile
The name of the index file within the SortedKeyValueFile directory.
IndexedRecord - Interface in org.apache.avro.generic
A record implementation that permits field access by integer index.
induce(Object) - Method in class org.apache.avro.generic.GenericData
Create a schema given an example datum.
InduceSchemaTool - Class in org.apache.avro.tool
Utility to induce a schema from a class or a protocol from an interface.
InduceSchemaTool() - Constructor for class org.apache.avro.tool.InduceSchemaTool
 
init(RuntimeServices) - Method in class org.apache.avro.compiler.specific.SpecificCompiler.Slf4jLogChute
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
initializeClientServer() - Method in class org.apache.avro.ipc.trace.TracePlugin
Start a client-facing server.
initSchema(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordWriter
Use the task context to construct a schema for writing
initSchema(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordWriter
Use the task context to construct a schema for writing
initSchema(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
Use the task context to construct a schema for writing
InMemorySpanStorage - Class in org.apache.avro.ipc.trace
Example implementation of SpanStorage which keeps spans in memory.
InMemorySpanStorage() - Constructor for class org.apache.avro.ipc.trace.InMemorySpanStorage
 
input(ByteBuffer, long) - Method in interface org.apache.avro.mapred.tether.InputProtocol
Send a block of input data to a task.
Input - Interface in org.apache.trevni
A byte source that supports positioned read and length.
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.
input_stream - Variable in class org.apache.avro.compiler.idl.IdlTokenManager
 
InputBytes - Class in org.apache.trevni
An Input backed with data in a byte array.
InputBytes(byte[]) - Constructor for class org.apache.trevni.InputBytes
Construct for the given bytes.
InputBytes(ByteBuffer) - Constructor for class org.apache.trevni.InputBytes
Construct for the given bytes.
InputFile - Class in org.apache.trevni
An Input for files.
InputFile(File) - Constructor for class org.apache.trevni.InputFile
Construct for the given file.
InputProtocol - Interface in org.apache.avro.mapred.tether
 
InputProtocol.Callback - Interface in org.apache.avro.mapred.tether
 
inputStream - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
inputStream() - Method in class org.apache.avro.io.BinaryDecoder
Returns an InputStream that is aware of any buffering that may occur in this BinaryDecoder.
INSTANCE - Static variable in class org.apache.avro.hadoop.util.AvroCharSequenceComparator
A singleton instance.
instanceOf(Schema, Object) - Method in class org.apache.avro.generic.GenericData
INT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
INT - Static variable in class org.apache.avro.io.parsing.Symbol
 
intBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build an int type that can set custom properties.
intBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build an int type that can set custom properties.
intBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build an int type that can set custom properties.
intCheckAction(int) - Static method in class org.apache.avro.io.parsing.Symbol
 
intDefault(int) - Method in class org.apache.avro.SchemaBuilder.IntDefault
Completes this field with the default value provided
INTEGER_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
intType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain int type without custom properties.
intType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain int type without custom properties.
intType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain int type without custom properties.
invoke(Object, Method, Object[]) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
 
Ipc - Class in org.apache.avro.ipc
IPC utilities, including client and server factories.
isArray(Object) - Method in class org.apache.avro.generic.GenericData
isArray(Object) - Method in class org.apache.avro.protobuf.ProtobufData
 
isArray(Object) - Method in class org.apache.avro.reflect.ReflectData
 
isArray() - Method in class org.apache.trevni.ColumnMetaData
Return true if this column is an array.
isArray(boolean) - Method in class org.apache.trevni.ColumnMetaData
Set whether this column is an array.
isBoolean(Object) - Method in class org.apache.avro.generic.GenericData
isBytes(Object) - Method in class org.apache.avro.generic.GenericData
isBytes(Object) - Method in class org.apache.avro.protobuf.ProtobufData
 
isBytes(Object) - Method in class org.apache.avro.reflect.ReflectData
 
isBytes(Object) - Method in class org.apache.avro.thrift.ThriftData
 
isCancelled() - Method in class org.apache.avro.ipc.CallFuture
 
isConnected() - Method in class org.apache.avro.ipc.NettyTransceiver
 
isConnected() - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
isConnected() - Method in class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
isConnected() - Method in class org.apache.avro.ipc.Transceiver
True if a handshake has been completed for this connection.
isCreateSetters() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
 
isDone() - Method in class org.apache.avro.ipc.CallFuture
 
isDouble(Object) - Method in class org.apache.avro.generic.GenericData
isEmpty - Variable in class org.apache.avro.io.JsonEncoder
Has anything been written into the collections?
isEmpty() - Method in class org.apache.avro.util.WeakIdentityHashMap
 
isEnd() - Method in class org.apache.avro.io.BinaryDecoder
Returns true if the current BinaryDecoder is at the end of its source data and cannot read any further without throwing an EOFException or other IOException.
isEnum(Object) - Method in class org.apache.avro.generic.GenericData
isEnum(Object) - Method in class org.apache.avro.specific.SpecificData
 
isEnum(Object) - Method in class org.apache.avro.thrift.ThriftData
 
isError() - Method in class org.apache.avro.ipc.RPCContext
Indicates whether an exception was generated at the server
isError() - Method in class org.apache.avro.Schema
Returns true if this record is an error type.
isFixed(Object) - Method in class org.apache.avro.generic.GenericData
isFloat(Object) - Method in class org.apache.avro.generic.GenericData
isFlushOnEveryBlock() - Method in class org.apache.avro.file.DataFileWriter
 
isInteger(Object) - Method in class org.apache.avro.generic.GenericData
isLevelEnabled(int) - Method in class org.apache.avro.compiler.specific.SpecificCompiler.Slf4jLogChute
 
isLong(Object) - Method in class org.apache.avro.generic.GenericData
isMap(Object) - Method in class org.apache.avro.generic.GenericData
isMultiNamedOutput(JobConf, String) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
Returns if a named output is multiple.
isOneWay() - Method in class org.apache.avro.Protocol.Message
Returns true if this is a one-way message, with no response or errors.
isRecord(Object) - Method in class org.apache.avro.generic.GenericData
isRecord(Object) - Method in class org.apache.avro.protobuf.ProtobufData
 
isRecord(Object) - Method in class org.apache.avro.reflect.ReflectData
 
isRecord(Object) - Method in class org.apache.avro.thrift.ThriftData
 
isReserved(String) - Static method in class org.apache.trevni.MetaData
Test if a metadata key is reserved.
isReservedMeta(String) - Static method in class org.apache.avro.file.DataFileWriter
 
isSplitable(FileSystem, Path) - Method in class org.apache.avro.mapred.AvroUtf8InputFormat
 
isSplitable(FileSystem, Path) - Method in class org.apache.trevni.avro.AvroTrevniInputFormat
 
isString(Object) - Method in class org.apache.avro.generic.GenericData
isStringable(Class<?>) - Method in class org.apache.avro.reflect.ReflectData
 
isStringable(Class<?>) - Method in class org.apache.avro.specific.SpecificData
True iff a class should be serialized with toString().
isTrailing - Variable in class org.apache.avro.io.parsing.Symbol.ImplicitAction
Set to true if and only if this implicit action is a trailing action.
isUnboxedJavaTypeNullable(Schema) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Tests whether an unboxed Java type can be set to null
isValidValue(Schema.Field, Object) - Static method in class org.apache.avro.data.RecordBuilderBase
Tests whether a value is valid for a specified field.
ITEM_END - Static variable in class org.apache.avro.io.parsing.Symbol
 
items() - Method in class org.apache.avro.SchemaBuilder.ArrayBuilder
Return a type builder for configuring the array's nested items schema.
items(Schema) - Method in class org.apache.avro.SchemaBuilder.ArrayBuilder
Complete configuration of this array, setting the schema of the array items to the schema provided.
iterator() - Method in class org.apache.avro.file.DataFileReader12
 
iterator() - Method in class org.apache.avro.file.DataFileStream
Returns an iterator over entries in this file.
iterator() - Method in class org.apache.avro.generic.GenericData.Array
 
iterator() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
Returns an iterator starting at the current position in the file.
iterator() - Method in class org.apache.avro.io.parsing.Symbol.Sequence
 
iterator() - Method in class org.apache.avro.mapred.SequenceFileReader
 
iterator() - Method in class org.apache.trevni.avro.AvroColumnReader
 
iterator() - Method in class org.apache.trevni.ColumnValues
 

J

javaAnnotations(JsonProperties) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
JavaCharStream - Class in org.apache.avro.compiler.idl
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (with java-like unicode escape processing).
JavaCharStream(Reader, int, int, int) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(Reader, int, int) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(Reader) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(InputStream, int, int, int) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(InputStream, String, int, int) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(InputStream, int, int) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(InputStream, String) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
JavaCharStream(InputStream) - Constructor for class org.apache.avro.compiler.idl.JavaCharStream
Constructor.
javaEscape(Object) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
javaSplit(String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
javaType(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
javaUnbox(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
jj_nt - Variable in class org.apache.avro.compiler.idl.Idl
Next token.
jjFillToken() - Method in class org.apache.avro.compiler.idl.IdlTokenManager
 
jjnewLexState - Static variable in class org.apache.avro.compiler.idl.IdlTokenManager
Lex State array.
jjstrLiteralImages - Static variable in class org.apache.avro.compiler.idl.IdlTokenManager
Token literal values.
job - Variable in class org.apache.avro.tool.TetherTool
 
join() - Method in class org.apache.avro.ipc.HttpServer
 
join() - Method in class org.apache.avro.ipc.NettyServer
 
join() - Method in interface org.apache.avro.ipc.Server
Wait for this server to exit.
Json() - Method in class org.apache.avro.compiler.idl.Idl
 
Json - Class in org.apache.avro.data
Utilities for reading and writing arbitrary Json data in Avro format.
Json.Reader - Class in org.apache.avro.data
DatumReader for arbitrary Json data.
Json.Reader() - Constructor for class org.apache.avro.data.Json.Reader
 
Json.Writer - Class in org.apache.avro.data
DatumWriter for arbitrary Json data.
Json.Writer() - Constructor for class org.apache.avro.data.Json.Writer
 
JsonArray() - Method in class org.apache.avro.compiler.idl.Idl
 
jsonDecoder(Schema, InputStream) - Method in class org.apache.avro.io.DecoderFactory
Creates a JsonDecoder using the InputStrim provided for reading data that conforms to the Schema provided.
jsonDecoder(Schema, String) - Method in class org.apache.avro.io.DecoderFactory
Creates a JsonDecoder using the String provided for reading data that conforms to the Schema provided.
JsonDecoder - Class in org.apache.avro.io
A Decoder for Avro's JSON data encoding.
JsonElements(ArrayNode) - Method in class org.apache.avro.compiler.idl.Idl
 
jsonEncoder(Schema, OutputStream) - Method in class org.apache.avro.io.EncoderFactory
Creates a JsonEncoder using the OutputStream provided for writing data conforming to the Schema provided.
jsonEncoder(Schema, OutputStream, boolean) - Method in class org.apache.avro.io.EncoderFactory
Creates a JsonEncoder using the OutputStream provided for writing data conforming to the Schema provided with optional pretty printing.
jsonEncoder(Schema, JsonGenerator) - Method in class org.apache.avro.io.EncoderFactory
Creates a JsonEncoder using the JsonGenerator provided for output of data conforming to the Schema provided.
JsonEncoder - Class in org.apache.avro.io
An Encoder for Avro's JSON data encoding.
JsonFields(ObjectNode) - Method in class org.apache.avro.compiler.idl.Idl
 
JsonGrammarGenerator - Class in org.apache.avro.io.parsing
The class that generates a grammar suitable to parse Avro data in JSON format.
JsonGrammarGenerator() - Constructor for class org.apache.avro.io.parsing.JsonGrammarGenerator
 
JsonObject() - Method in class org.apache.avro.compiler.idl.Idl
 
JsonPair(ObjectNode) - Method in class org.apache.avro.compiler.idl.Idl
 
JsonProperties - Class in org.apache.avro
Base class for objects that have Json-valued properties.
JsonString() - Method in class org.apache.avro.compiler.idl.Idl
 
JsonToBinaryFragmentTool - Class in org.apache.avro.tool
Tool to convert JSON data into the binary form.
JsonToBinaryFragmentTool() - Constructor for class org.apache.avro.tool.JsonToBinaryFragmentTool
 

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_CLASS_PROP - Static variable in class org.apache.avro.specific.SpecificData
 
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.
keySet() - Method in class org.apache.avro.util.WeakIdentityHashMap
 
kind - Variable in class org.apache.avro.compiler.idl.Token
An integer that describes the kind of this token.
kind - Variable in class org.apache.avro.io.parsing.Symbol
 

L

labels - Variable in class org.apache.avro.io.parsing.Symbol.Alternative
 
LBRACE - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
LBRACK - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
length() - Method in class org.apache.avro.file.SeekableByteArrayInput
 
length() - Method in class org.apache.avro.file.SeekableFileInput
 
length() - Method in interface org.apache.avro.file.SeekableInput
Return the length of the file.
length() - Method in class org.apache.avro.mapred.FsInput
 
length() - Method in class org.apache.avro.util.Utf8
 
length() - Method in class org.apache.trevni.avro.HadoopInput
 
length() - Method in interface org.apache.trevni.Input
Return the total length of the input.
length() - Method in class org.apache.trevni.InputBytes
 
length() - Method in class org.apache.trevni.InputFile
 
LETTER - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.avro.compiler.idl.TokenMgrError
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
lexStateNames - Static variable in class org.apache.avro.compiler.idl.IdlTokenManager
Lexer state names.
line - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
listStatus(JobConf) - Method in class org.apache.avro.mapred.AvroAsTextInputFormat
 
listStatus(JobConf) - Method in class org.apache.avro.mapred.AvroInputFormat
 
listStatus(JobConf) - Method in class org.apache.trevni.avro.AvroTrevniInputFormat
 
LocalTransceiver - Class in org.apache.avro.ipc
Implementation of IPC that remains in process.
LocalTransceiver(Responder) - Constructor for class org.apache.avro.ipc.LocalTransceiver
 
lockChannel() - Method in class org.apache.avro.ipc.NettyTransceiver
Netty channels are thread-safe, so there is no need to acquire locks.
lockChannel() - Method in class org.apache.avro.ipc.Transceiver
Acquires an exclusive lock on the transceiver's channel.
log(int, String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler.Slf4jLogChute
 
log(int, String, Throwable) - Method in class org.apache.avro.compiler.specific.SpecificCompiler.Slf4jLogChute
 
LONG - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
LONG - Static variable in class org.apache.avro.io.parsing.Symbol
 
longBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build a long type that can set custom properties.
longBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build a long type that can set custom properties.
longBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build a long type that can set custom properties.
longDefault(long) - Method in class org.apache.avro.SchemaBuilder.LongDefault
Completes this field with the default value provided
longestTraces(int) - Method in class org.apache.avro.ipc.trace.TraceCollection
Returns the [count] longest traces in this collection.
longType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain long type without custom properties.
longType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain long type without custom properties.
longType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain long type without custom properties.
lookupWriterField(Schema, Schema.Field) - Static method in class org.apache.avro.SchemaCompatibility
Identifies the writer field that corresponds to the specified reader field.
LPAREN - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
LT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.

M

MAGIC - Static variable in class org.apache.avro.file.DataFileConstants
 
main(String[]) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
 
main(String[]) - Static method in class org.apache.avro.ipc.DatagramServer
 
main(String[]) - Static method in class org.apache.avro.ipc.SocketServer
Deprecated.
 
main(String[]) - Static method in class org.apache.avro.Protocol
 
Main - Class in org.apache.avro.tool
Command-line driver.
main(String[]) - Static method in class org.apache.avro.tool.Main
 
makeNullable(Schema) - Static method in class org.apache.avro.reflect.ReflectData
Create and return a union of the null schema and the provided schema.
mangle(String) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
mangle(String, boolean) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
mangle(String, Set<String>) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
mangle(String, Set<String>, boolean) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
MAP - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
map(IN, AvroCollector<OUT>, Reporter) - Method in class org.apache.avro.mapred.AvroMapper
Called with each map input datum.
map() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build an Avro map type
map() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build an Avro map type Example usage:
map() - Static method in class org.apache.avro.SchemaBuilder
Create a builder for an Avro map This is equivalent to:
map() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build an Avro map type
MAP_END - Static variable in class org.apache.avro.io.parsing.Symbol
 
MAP_KEY_MARKER - Static variable in class org.apache.avro.io.parsing.Symbol
 
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.
MAP_START - Static variable in class org.apache.avro.io.parsing.Symbol
 
mapDefault(Map<K, V>) - Method in class org.apache.avro.SchemaBuilder.MapDefault
Completes this field with the default value provided, cannot be null
mapNext() - Method in class org.apache.avro.io.BinaryDecoder
 
mapNext() - Method in class org.apache.avro.io.Decoder
Processes the next block of map entries and returns the count of them.
mapNext() - Method in class org.apache.avro.io.JsonDecoder
 
mapNext() - Method in class org.apache.avro.io.ValidatingDecoder
 
MapType() - Method in class org.apache.avro.compiler.idl.Idl
 
match - Variable in class org.apache.avro.ipc.HandshakeResponse
Deprecated.
maxNextCharInd - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
maxSpans - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
MD5 - Class in org.apache.avro.ipc
 
MD5() - Constructor for class org.apache.avro.ipc.MD5
Creates a new MD5
MD5(byte[]) - Constructor for class org.apache.avro.ipc.MD5
Creates a new MD5 with the given bytes
MessageDeclaration(Protocol, Map<String, JsonNode>) - Method in class org.apache.avro.compiler.idl.Idl
 
MessageDocumentation() - Method in class org.apache.avro.compiler.idl.Idl
 
messageName - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.avro.ipc.NettyTransceiver.NettyClientAvroHandler
 
meta - Variable in class org.apache.avro.ipc.HandshakeRequest
Deprecated.
meta - Variable in class org.apache.avro.ipc.HandshakeResponse
Deprecated.
meta - Variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
meta data to be stored in the output file.
META_PREFIX - Static variable in class org.apache.trevni.avro.AvroTrevniOutputFormat
 
META_PREFIX - Static variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
prefix of job configs that we care about
MetaData<T extends MetaData> - Class in org.apache.trevni
Base class for metadata.
MetaData() - Constructor for class org.apache.trevni.MetaData
 
METADATA_FIELD_KEY_SCHEMA - Static variable in class org.apache.avro.hadoop.io.AvroSequenceFile
The SequencFile.Metadata field for the Avro key writer schema.
METADATA_FIELD_VALUE_SCHEMA - Static variable in class org.apache.avro.hadoop.io.AvroSequenceFile
The SequencFile.Metadata field for the Avro value writer schema.
MILLIS_PER_SECOND - Static variable in interface org.apache.avro.ipc.trace.SpanStorage
 
msg - Variable in class org.apache.avro.io.parsing.Symbol.ErrorAction
 
MULTI_LINE_COMMENT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
Lexical state.

N

name - Variable in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
 
name() - Method in class org.apache.avro.Schema.Field
 
name(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Add a field with the given name.
NamedSchemaDeclaration(Map<String, JsonNode>) - Method in class org.apache.avro.compiler.idl.Idl
 
names - Variable in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
 
namespace(String) - Method in class org.apache.avro.SchemaBuilder.NamespacedBuilder
Set the namespace of this type.
NANOS_PER_SECOND - Static variable in interface org.apache.avro.ipc.trace.SpanStorage
 
NETTY_CONNECT_TIMEOUT_OPTION - Static variable in class org.apache.avro.ipc.NettyTransceiver
 
NETTY_KEEPALIVE_OPTION - Static variable in class org.apache.avro.ipc.NettyTransceiver
 
NETTY_TCP_NODELAY_OPTION - Static variable in class org.apache.avro.ipc.NettyTransceiver
 
NettyServer - Class in org.apache.avro.ipc
A Netty-based RPC Server implementation.
NettyServer(Responder, InetSocketAddress) - Constructor for class org.apache.avro.ipc.NettyServer
 
NettyServer(Responder, InetSocketAddress, ChannelFactory) - Constructor for class org.apache.avro.ipc.NettyServer
 
NettyServer(Responder, InetSocketAddress, ChannelFactory, ChannelPipelineFactory, ExecutionHandler) - Constructor for class org.apache.avro.ipc.NettyServer
 
NettyServer(Responder, InetSocketAddress, ChannelFactory, ExecutionHandler) - Constructor for class org.apache.avro.ipc.NettyServer
 
NettyTransceiver - Class in org.apache.avro.ipc
A Netty-based Transceiver implementation.
NettyTransceiver(InetSocketAddress) - Constructor for class org.apache.avro.ipc.NettyTransceiver
Creates a NettyTransceiver, and attempts to connect to the given address.
NettyTransceiver(InetSocketAddress, Long) - Constructor for class org.apache.avro.ipc.NettyTransceiver
Creates a NettyTransceiver, and attempts to connect to the given address.
NettyTransceiver(InetSocketAddress, ChannelFactory) - Constructor for class org.apache.avro.ipc.NettyTransceiver
Creates a NettyTransceiver, and attempts to connect to the given address.
NettyTransceiver(InetSocketAddress, ChannelFactory, Long) - Constructor for class org.apache.avro.ipc.NettyTransceiver
Creates a NettyTransceiver, and attempts to connect to the given address.
NettyTransceiver(InetSocketAddress, ChannelFactory, Map<String, Object>) - Constructor for class org.apache.avro.ipc.NettyTransceiver
Creates a NettyTransceiver, and attempts to connect to the given address.
NettyTransceiver.NettyClientAvroHandler - Class in org.apache.avro.ipc
Avro client handler for the Netty transport
NettyTransceiver.NettyClientAvroHandler() - Constructor for class org.apache.avro.ipc.NettyTransceiver.NettyClientAvroHandler
 
NettyTransceiver.NettyTransceiverThreadFactory - Class in org.apache.avro.ipc
Creates threads with unique names based on a specified name prefix.
NettyTransceiver.NettyTransceiverThreadFactory(String) - Constructor for class org.apache.avro.ipc.NettyTransceiver.NettyTransceiverThreadFactory
Creates a NettyTransceiverThreadFactory that creates threads with the specified name.
NettyTransceiver.WriteFutureListener - Class in org.apache.avro.ipc
A ChannelFutureListener for channel write operations that notifies a Callback if an error occurs while writing to the channel.
NettyTransceiver.WriteFutureListener(Callback<List<ByteBuffer>>) - Constructor for class org.apache.avro.ipc.NettyTransceiver.WriteFutureListener
Creates a WriteFutureListener that notifies the given callback if an error occurs writing data to the channel.
NettyTransportCodec - Class in org.apache.avro.ipc
Data structure, encoder and decoder classes for the Netty transport.
NettyTransportCodec() - Constructor for class org.apache.avro.ipc.NettyTransportCodec
 
NettyTransportCodec.NettyDataPack - Class in org.apache.avro.ipc
Transport protocol data structure when using Netty.
NettyTransportCodec.NettyDataPack() - Constructor for class org.apache.avro.ipc.NettyTransportCodec.NettyDataPack
 
NettyTransportCodec.NettyDataPack(int, List<ByteBuffer>) - Constructor for class org.apache.avro.ipc.NettyTransportCodec.NettyDataPack
 
NettyTransportCodec.NettyFrameDecoder - Class in org.apache.avro.ipc
Protocol decoder which converts Netty's ChannelBuffer to NettyDataPack which contains a List<ByteBuffer> needed by Avro Responder.
NettyTransportCodec.NettyFrameDecoder() - Constructor for class org.apache.avro.ipc.NettyTransportCodec.NettyFrameDecoder
 
NettyTransportCodec.NettyFrameEncoder - Class in org.apache.avro.ipc
Protocol encoder which converts NettyDataPack which contains the Responder's output List<ByteBuffer> to ChannelBuffer needed by Netty.
NettyTransportCodec.NettyFrameEncoder() - Constructor for class org.apache.avro.ipc.NettyTransportCodec.NettyFrameEncoder
 
newArray(Object, int, Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Called to create new array instances.
newArray(Object, int, Schema) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
newArray(Object, int, Schema) - Method in class org.apache.avro.thrift.ThriftDatumReader
 
newBuilder() - Static method in class org.apache.avro.ipc.HandshakeRequest
Creates a new HandshakeRequest RecordBuilder
newBuilder(HandshakeRequest.Builder) - Static method in class org.apache.avro.ipc.HandshakeRequest
Creates a new HandshakeRequest RecordBuilder by copying an existing Builder
newBuilder(HandshakeRequest) - Static method in class org.apache.avro.ipc.HandshakeRequest
Creates a new HandshakeRequest RecordBuilder by copying an existing HandshakeRequest instance
newBuilder() - Static method in class org.apache.avro.ipc.HandshakeResponse
Creates a new HandshakeResponse RecordBuilder
newBuilder(HandshakeResponse.Builder) - Static method in class org.apache.avro.ipc.HandshakeResponse
Creates a new HandshakeResponse RecordBuilder by copying an existing Builder
newBuilder(HandshakeResponse) - Static method in class org.apache.avro.ipc.HandshakeResponse
Creates a new HandshakeResponse RecordBuilder by copying an existing HandshakeResponse instance
newBuilder() - Static method in class org.apache.avro.ipc.trace.Span
Creates a new Span RecordBuilder
newBuilder(Span.Builder) - Static method in class org.apache.avro.ipc.trace.Span
Creates a new Span RecordBuilder by copying an existing Builder
newBuilder(Span) - Static method in class org.apache.avro.ipc.trace.Span
Creates a new Span RecordBuilder by copying an existing Span instance
newBuilder() - Static method in class org.apache.avro.ipc.trace.TimestampedEvent
Creates a new TimestampedEvent RecordBuilder
newBuilder(TimestampedEvent.Builder) - Static method in class org.apache.avro.ipc.trace.TimestampedEvent
Creates a new TimestampedEvent RecordBuilder by copying an existing Builder
newBuilder(TimestampedEvent) - Static method in class org.apache.avro.ipc.trace.TimestampedEvent
Creates a new TimestampedEvent RecordBuilder by copying an existing TimestampedEvent instance
newInstance(Class, Schema) - Static method in class org.apache.avro.specific.SpecificData
Create an instance of a class.
newInstanceFromString(Class, String) - Method in class org.apache.avro.generic.GenericDatumReader
 
newMap(Object, int) - Method in class org.apache.avro.generic.GenericDatumReader
Called to create new array instances.
newRecord(Object, Schema) - Method in class org.apache.avro.generic.GenericData
Called to create new record instances.
newRecord(Object, Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Deprecated.
As of Avro 1.6.0 this method has been moved to GenericData.newRecord(Object, Schema)
newRecord(Object, Schema) - Method in class org.apache.avro.protobuf.ProtobufData
 
newRecord(Object, Schema) - Method in class org.apache.avro.specific.SpecificData
 
newRecord(Object, Schema) - Method in class org.apache.avro.thrift.ThriftData
 
newThread(Runnable) - Method in class org.apache.avro.ipc.NettyTransceiver.NettyTransceiverThreadFactory
 
newToken(int, String) - Static method in class org.apache.avro.compiler.idl.Token
Returns a new Token object, by default.
newToken(int) - Static method in class org.apache.avro.compiler.idl.Token
 
next - Variable in class org.apache.avro.compiler.idl.Token
A reference to the next regular (non-special) token from the input stream.
next() - Method in class org.apache.avro.file.DataFileReader12
 
next(D) - Method in class org.apache.avro.file.DataFileReader12
Return the next datum in the file.
next() - Method in class org.apache.avro.file.DataFileStream
Read the next datum in the file.
next(D) - Method in class org.apache.avro.file.DataFileStream
Read the next datum from the file.
next(D) - Method in interface org.apache.avro.file.FileReader
Read the next datum from the file.
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
 
next() - Method in class org.apache.trevni.avro.AvroColumnReader
 
next() - Method in class org.apache.trevni.ColumnValues
 
nextBlock() - Method in class org.apache.avro.file.DataFileStream
Expert: Return the next block in the file, as binary-encoded data.
nextCharBuf - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
nextCharInd - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
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
nextKeyValue() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordReader
nextKeyValue() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordReader
nextKeyValue() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
nextLength() - Method in class org.apache.trevni.ColumnValues
Expert: Returns the next length in an array column.
nextValue() - Method in class org.apache.trevni.ColumnValues
Expert: Returns the next value in a column.
noDefault() - Method in class org.apache.avro.SchemaBuilder.FieldDefault
Completes this field with no default value
noDefault() - Method in class org.apache.avro.SchemaBuilder.GenericDefault
Do not use a default value for this field.
npe(NullPointerException, String) - Method in class org.apache.avro.generic.GenericDatumWriter
Helper method for adding a message to an NPE.
NULL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
NULL - Static variable in class org.apache.avro.io.parsing.Symbol
The terminal symbols for the grammar.
NULL - Static variable in annotation type org.apache.avro.reflect.AvroAlias
 
NULL_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
 
Nullable - Annotation Type in org.apache.avro.reflect
Declares that null is a valid value for a Java type.
nullable() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A shortcut for building a union of a type and null.
nullable() - Method in class org.apache.avro.SchemaBuilder.FieldTypeBuilder
A shortcut for building a union of a type and null, with an optional default value of the non-null type.
nullable() - Static method in class org.apache.avro.SchemaBuilder
Create a builder for a union of a type and null.
nullable() - Method in class org.apache.avro.SchemaBuilder.TypeBuilder
 
nullableBoolean(String, boolean) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a nullable boolean field: a union of boolean and null with an boolean default.
nullableBytes(String, byte[]) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a nullable bytes field: a union of bytes and null with a bytes default.

This is equivalent to:

nullableDouble(String, double) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a nullable double field: a union of double and null with a double default.

This is equivalent to:

nullableFloat(String, float) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a nullable float field: a union of float and null with a float default.

This is equivalent to:

nullableInt(String, int) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a nullable int field: a union of int and null with an int default.

This is equivalent to:

nullableLong(String, long) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a nullable long field: a union of long and null with a long default.

This is equivalent to:

nullableString(String, String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a nullable string field: a union of string and null with a string default.

This is equivalent to:

nullBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build a null type that can set custom properties.
nullBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build a null type that can set custom properties.
nullBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build a null type that can set custom properties.
nullCodec() - Static method in class org.apache.avro.file.CodecFactory
Null codec, for no compression.
nullDefault() - Method in class org.apache.avro.SchemaBuilder.NullDefault
Completes this field with a default value of null
nullToEmpty(String) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
Utility for template use.
nullType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain null type without custom properties.
nullType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain null type without custom properties.
nullType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain null type without custom properties.
numCalls - Variable in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
 

O

OCTAL_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
ONEWAY - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
open(InputStream) - Method in class org.apache.avro.hadoop.io.AvroDeserializer
open(OutputStream) - Method in class org.apache.avro.hadoop.io.AvroSerializer
openReader(File, DatumReader<D>) - Static method in class org.apache.avro.file.DataFileReader
Open a reader for a file.
openReader(SeekableInput, DatumReader<D>) - Static method in class org.apache.avro.file.DataFileReader
Open a reader for a file.
openReader(SeekableInput, DatumReader<D>, DataFileStream.Header, boolean) - Static method in class org.apache.avro.file.DataFileReader
Construct a reader for a file at the current position of the input, without reading the header.
operationComplete(ChannelFuture) - Method in class org.apache.avro.ipc.NettyTransceiver.WriteFutureListener
 
optional() - Method in class org.apache.avro.SchemaBuilder.FieldTypeBuilder
A shortcut for building a union of null and a type, with a null default.
optionalBoolean(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an optional boolean field: a union of null and boolean with null default.

This is equivalent to:

optionalBytes(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an optional bytes field: a union of null and bytes with null default.

This is equivalent to:

optionalDouble(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an optional double field: a union of null and double with null default.

This is equivalent to:

optionalFloat(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an optional float field: a union of null and float with null default.

This is equivalent to:

optionalInt(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an optional int field: a union of null and int with null default.

This is equivalent to:

optionalLong(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an optional long field: a union of null and long with null default.

This is equivalent to:

optionalString(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an optional string field: a union of null and string with null default.

This is equivalent to:

order() - Method in class org.apache.avro.Schema.Field
 
orderAscending() - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
Set this field to have ascending order.
orderDescending() - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
Set this field to have decending order.
orderIgnore() - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
Set this field to ignore order.
org.apache.avro - package org.apache.avro
Avro kernel classes.
org.apache.avro.compiler.idl - package org.apache.avro.compiler.idl
 
org.apache.avro.compiler.specific - package org.apache.avro.compiler.specific
 
org.apache.avro.data - package org.apache.avro.data
Interfaces and base classes shared by generic, specific and reflect.
org.apache.avro.file - package org.apache.avro.file
A container file for Avro data.
org.apache.avro.generic - package org.apache.avro.generic
A generic representation for Avro data.
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.io - package org.apache.avro.io
Utilities for Encoding and Decoding Avro data.
org.apache.avro.io.parsing - package org.apache.avro.io.parsing
Implementation of Avro schemas as LL(1) grammars.
org.apache.avro.ipc - package org.apache.avro.ipc
Support for inter-process calls.
org.apache.avro.ipc.generic - package org.apache.avro.ipc.generic
 
org.apache.avro.ipc.reflect - package org.apache.avro.ipc.reflect
 
org.apache.avro.ipc.specific - package org.apache.avro.ipc.specific
 
org.apache.avro.ipc.stats - package org.apache.avro.ipc.stats
Utilities to collect and display IPC statistics.
org.apache.avro.ipc.trace - package org.apache.avro.ipc.trace
 
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
 
org.apache.avro.mojo - package org.apache.avro.mojo
 
org.apache.avro.protobuf - package org.apache.avro.protobuf
Protocol Buffer compatibility.
org.apache.avro.reflect - package org.apache.avro.reflect
Use Java reflection to generate schemas and protocols for existing classes.
org.apache.avro.specific - package org.apache.avro.specific
Generate specific Java classes for schemas and protocols.
org.apache.avro.thrift - package org.apache.avro.thrift
Thrift compatibility.
org.apache.avro.tool - package org.apache.avro.tool
Avro command-line tool.
org.apache.avro.util - package org.apache.avro.util
Common utility classes.
org.apache.trevni - package org.apache.trevni
A column file format.
org.apache.trevni.avro - package org.apache.trevni.avro
Read and write Avro data in Trevni column files.
org.apache.trevni.avro.mapreduce - package org.apache.trevni.avro.mapreduce
 
out - Variable in class org.apache.avro.io.ValidatingEncoder
 
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
 
OutputProtocol.Callback - Interface in org.apache.avro.mapred.tether
 

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
 
parentSpanID - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
parse(File) - Static method in class org.apache.avro.Protocol
Read a protocol from a Json file.
parse(InputStream) - Static method in class org.apache.avro.Protocol
Read a protocol from a Json stream.
parse(String, String...) - Static method in class org.apache.avro.Protocol
Read a protocol from one or more json strings
parse(String) - Static method in class org.apache.avro.Protocol
Read a protocol from a Json string.
parse(File) - Static method in class org.apache.avro.Schema
Deprecated.
use Schema.Parser instead.
parse(InputStream) - Static method in class org.apache.avro.Schema
Deprecated.
use Schema.Parser instead.
parse(String) - Static method in class org.apache.avro.Schema
Deprecated.
use Schema.Parser instead.
parse(String, boolean) - Static method in class org.apache.avro.Schema
Deprecated.
use Schema.Parser instead.
parse(File) - Method in class org.apache.avro.Schema.Parser
Parse a schema from the provided file.
parse(InputStream) - Method in class org.apache.avro.Schema.Parser
Parse a schema from the provided stream.
parse(String, String...) - Method in class org.apache.avro.Schema.Parser
Read a schema from one or more json strings
parse(String) - Method in class org.apache.avro.Schema.Parser
Parse a schema from the provided string.
ParseException - Exception in org.apache.avro.compiler.idl
This exception is thrown when parse errors are encountered.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.avro.compiler.idl.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.apache.avro.compiler.idl.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.apache.avro.compiler.idl.ParseException
Constructor with message.
parseJson(String) - Static method in class org.apache.avro.Schema
Parses a string as Json.
Parser - Class in org.apache.avro.io.parsing
Parser is the class that maintains the stack for parsing.
Parser(Symbol, Parser.ActionHandler) - Constructor for class org.apache.avro.io.parsing.Parser
 
parser - Variable in class org.apache.avro.io.ParsingDecoder
 
parser - Variable in class org.apache.avro.io.ValidatingEncoder
 
Parser.ActionHandler - Interface in org.apache.avro.io.parsing
The parser knows how to handle the terminal and non-terminal symbols.
ParsingDecoder - Class in org.apache.avro.io
Base class for parser-based Decoders.
ParsingDecoder(Symbol) - Constructor for class org.apache.avro.io.ParsingDecoder
 
ParsingEncoder - Class in org.apache.avro.io
Base class for parser-based Encoders.
ParsingEncoder() - Constructor for class org.apache.avro.io.ParsingEncoder
 
parsingFingerprint(String, Schema) - Static method in class org.apache.avro.SchemaNormalization
Returns SchemaNormalization.fingerprint(java.lang.String, byte[]) applied to the parsing canonical form of the supplied schema.
parsingFingerprint64(Schema) - Static method in class org.apache.avro.SchemaNormalization
Returns SchemaNormalization.fingerprint64(byte[]) applied to the parsing canonical form of the supplied schema.
part - Variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
Counter that increments as new trevni files are create because the current file has exceeded the block size
PART_LETTER - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
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.file.DataFileReader
Return true if past the next synchronization point after a position.
pastSync(long) - Method in class org.apache.avro.file.DataFileReader12
Return true if past the next synchronization point after a position.
pastSync(long) - Method in interface org.apache.avro.file.FileReader
Return true if past the next synchronization point after a position.
pastSync(long) - Method in class org.apache.avro.mapred.SequenceFileReader
 
peek() - Method in interface org.apache.avro.generic.GenericArray
The current content of the location where List.add(Object) would next store an element, if any.
peek() - Method in class org.apache.avro.generic.GenericData.Array
 
peekArray(Object) - Method in class org.apache.avro.generic.GenericDatumReader
Called by the default implementation of GenericDatumReader.readArray(java.lang.Object, org.apache.avro.Schema, org.apache.avro.io.ResolvingDecoder) to retrieve a value from a reused instance.
peekArray(Object) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
pop() - Method in class org.apache.avro.io.ParsingEncoder
 
popSymbol() - Method in class org.apache.avro.io.parsing.Parser
Pops and returns the top symbol from the stack.
port - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
pos - Variable in class org.apache.avro.io.parsing.Parser
 
pos - Variable in class org.apache.avro.io.ParsingEncoder
 
pos() - Method in class org.apache.avro.Schema.Field
The position of this field within the record.
prepend(List<ByteBuffer>) - Method in class org.apache.avro.util.ByteBufferOutputStream
Prepend a list of ByteBuffers to this stream.
prevCharIsCR - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
prevCharIsLF - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
previousSync() - Method in class org.apache.avro.file.DataFileReader
Return the last synchronization point before our current position.
PrimitiveType() - Method in class org.apache.avro.compiler.idl.Idl
 
printBrief() - Method in class org.apache.avro.ipc.trace.Trace
Print a brief description of this trace describing the execution path, but not timing data.
printBrief() - Method in class org.apache.avro.ipc.trace.TraceCollection
Print a brief description of this Trace Collection with some summary data.
printBrief() - Method in class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
 
printRecurse(TraceCollection.TraceNodeStats, int) - Method in class org.apache.avro.ipc.trace.TraceCollection
 
printWithTiming() - Method in class org.apache.avro.ipc.trace.Trace
Print a description of this trace which includes timing data.
privateFields() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
 
processImplicitActions() - Method in class org.apache.avro.io.parsing.Parser
Performs any implicit actions at the top the stack, expanding any production (other than the root) that may be encountered.
processTrailingImplicitActions() - Method in class org.apache.avro.io.parsing.Parser
Performs any "trailing" implicit actions at the top the stack.
production - Variable in class org.apache.avro.io.parsing.Symbol
The production for this symbol.
project - Variable in class org.apache.avro.mojo.AbstractAvroMojo
The current Maven project.
prop(String, String) - Method in class org.apache.avro.SchemaBuilder.PropBuilder
Set name-value pair properties for this type or field.
PropertyName() - Method in class org.apache.avro.compiler.idl.Idl
 
props() - Method in class org.apache.avro.Schema.Field
Deprecated.
ProtobufData - Class in org.apache.avro.protobuf
Utilities for serializing Protobuf data in Avro format.
ProtobufData() - Constructor for class org.apache.avro.protobuf.ProtobufData
 
ProtobufDatumReader<T> - Class in org.apache.avro.protobuf
DatumReader for generated Protobuf classes.
ProtobufDatumReader() - Constructor for class org.apache.avro.protobuf.ProtobufDatumReader
 
ProtobufDatumReader(Class<T>) - Constructor for class org.apache.avro.protobuf.ProtobufDatumReader
 
ProtobufDatumReader(Schema) - Constructor for class org.apache.avro.protobuf.ProtobufDatumReader
Construct where the writer's and reader's schemas are the same.
ProtobufDatumReader(Schema, Schema) - Constructor for class org.apache.avro.protobuf.ProtobufDatumReader
Construct given writer's and reader's schema.
ProtobufDatumReader(Schema, Schema, ProtobufData) - Constructor for class org.apache.avro.protobuf.ProtobufDatumReader
 
ProtobufDatumWriter<T> - Class in org.apache.avro.protobuf
DatumWriter for generated protobuf classes.
ProtobufDatumWriter() - Constructor for class org.apache.avro.protobuf.ProtobufDatumWriter
 
ProtobufDatumWriter(Class<T>) - Constructor for class org.apache.avro.protobuf.ProtobufDatumWriter
 
ProtobufDatumWriter(Schema) - Constructor for class org.apache.avro.protobuf.ProtobufDatumWriter
 
ProtobufDatumWriter(Schema, ProtobufData) - Constructor for class org.apache.avro.protobuf.ProtobufDatumWriter
 
ProtobufDatumWriter(ProtobufData) - Constructor for class org.apache.avro.protobuf.ProtobufDatumWriter
 
PROTOCOL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
PROTOCOL - Static variable in interface org.apache.avro.ipc.trace.AvroTrace.Callback
 
PROTOCOL - Static variable in interface org.apache.avro.ipc.trace.AvroTrace
 
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
 
Protocol - Class in org.apache.avro
A set of messages forming an application protocol.
Protocol(String, String, String) - Constructor for class org.apache.avro.Protocol
 
Protocol(String, String) - Constructor for class org.apache.avro.Protocol
 
Protocol.Message - Class in org.apache.avro
A protocol message.
ProtocolBody(Protocol) - Method in class org.apache.avro.compiler.idl.Idl
 
ProtocolDeclaration() - Method in class org.apache.avro.compiler.idl.Idl
 
ProtocolMojo - Class in org.apache.avro.mojo
Generate Java classes and interfaces from Avro protocol files (.avpr)
ProtocolMojo() - Constructor for class org.apache.avro.mojo.ProtocolMojo
 
ProtocolTask - Class in org.apache.avro.compiler.specific
Ant task to generate Java interface and classes for a protocol.
ProtocolTask() - Constructor for class org.apache.avro.compiler.specific.ProtocolTask
 
publicFields() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
 
push() - Method in class org.apache.avro.io.ParsingEncoder
Push a new collection on to the stack.
pushProduction(Symbol) - Method in class org.apache.avro.io.parsing.Parser
Pushes the production for the given symbol sym.
pushSymbol(Symbol) - Method in class org.apache.avro.io.parsing.Parser
Pushes sym on to the stack.
put(String, Object) - Method in class org.apache.avro.generic.GenericData.Record
 
put(int, Object) - Method in class org.apache.avro.generic.GenericData.Record
 
put(String, Object) - Method in interface org.apache.avro.generic.GenericRecord
Set the value of a field given its name.
put(int, Object) - Method in interface org.apache.avro.generic.IndexedRecord
Set the value of a field given its position in the schema.
put(int, Object) - Method in class org.apache.avro.ipc.HandshakeRequest
 
put(int, Object) - Method in class org.apache.avro.ipc.HandshakeResponse
 
put(int, Object) - Method in class org.apache.avro.ipc.trace.Span
 
put(int, Object) - Method in class org.apache.avro.ipc.trace.TimestampedEvent
 
put(int, Object) - Method in class org.apache.avro.mapred.Pair
 
put(int, Object) - Method in exception org.apache.avro.specific.SpecificExceptionBase
 
put(int, Object) - Method in class org.apache.avro.specific.SpecificRecordBase
 
put(String, Object) - Method in class org.apache.avro.specific.SpecificRecordBase
 
put(K, V) - Method in class org.apache.avro.util.WeakIdentityHashMap
 
putAll(Map) - Method in class org.apache.avro.util.WeakIdentityHashMap
 

R

RBRACE - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
RBRACK - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
read(Decoder) - Static method in class org.apache.avro.data.Json
Read Json data from Avro data.
read(JsonNode, Decoder) - Method in class org.apache.avro.data.Json.Reader
 
read(byte[], int, int) - Method in interface org.apache.avro.file.SeekableInput
read(D, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
 
read(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read data.
read(D, Decoder) - Method in interface org.apache.avro.io.DatumReader
Read a datum.
read(byte[], int, int) - Method in class org.apache.avro.mapred.FsInput
 
read(Object, Decoder) - Method in class org.apache.avro.reflect.CustomEncoding
 
read(Object, Decoder) - Method in class org.apache.avro.reflect.DateAsLongEncoding
 
read() - Method in class org.apache.avro.util.ByteBufferInputStream
 
read(byte[], int, int) - Method in class org.apache.avro.util.ByteBufferInputStream
 
read(long, byte[], int, int) - Method in class org.apache.trevni.avro.HadoopInput
 
read(long, byte[], int, int) - Method in interface org.apache.trevni.Input
Positioned read.
read(long, byte[], int, int) - Method in class org.apache.trevni.InputBytes
 
read(long, byte[], int, int) - Method in class org.apache.trevni.InputFile
 
readArray(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read an array instance.
readArray(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
readArrayStart() - Method in class org.apache.avro.io.BinaryDecoder
 
readArrayStart() - Method in class org.apache.avro.io.Decoder
Reads and returns the size of the first block of an array.
readArrayStart() - Method in class org.apache.avro.io.JsonDecoder
 
readArrayStart() - Method in class org.apache.avro.io.ValidatingDecoder
 
readBoolean() - Method in class org.apache.avro.io.BinaryDecoder
 
readBoolean() - Method in class org.apache.avro.io.Decoder
Reads a boolean value written by Encoder.writeBoolean(boolean).
readBoolean() - Method in class org.apache.avro.io.JsonDecoder
 
readBoolean() - Method in class org.apache.avro.io.ValidatingDecoder
 
readBuffer(int) - Method in class org.apache.avro.util.ByteBufferInputStream
Read a buffer from the input without copying, if possible.
readBuffers() - Method in class org.apache.avro.ipc.DatagramTransceiver
 
readBuffers() - Method in class org.apache.avro.ipc.HttpTransceiver
 
readBuffers() - Method in class org.apache.avro.ipc.LocalTransceiver
 
readBuffers() - Method in class org.apache.avro.ipc.NettyTransceiver
 
readBuffers() - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
readBuffers() - Method in class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
readBuffers() - Method in class org.apache.avro.ipc.Transceiver
Called by the default definition of Transceiver.transceive(List).
ReadByte() - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
readBytes(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read byte arrays.
readBytes(Object, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read byte arrays.
readBytes(ByteBuffer) - Method in class org.apache.avro.io.BinaryDecoder
 
readBytes(ByteBuffer) - Method in class org.apache.avro.io.Decoder
Reads a byte-string written by Encoder.writeBytes(java.nio.ByteBuffer).
readBytes(ByteBuffer) - Method in class org.apache.avro.io.JsonDecoder
 
readBytes(ByteBuffer) - Method in class org.apache.avro.io.ValidatingDecoder
 
readBytes(Object, Decoder) - Method in class org.apache.avro.protobuf.ProtobufDatumReader
 
readBytes(Object, Schema, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
readChar() - Method in class org.apache.avro.compiler.idl.JavaCharStream
Read a character.
readDouble() - Method in class org.apache.avro.io.BinaryDecoder
 
readDouble() - Method in class org.apache.avro.io.Decoder
Reads a double written by Encoder.writeDouble(double).
readDouble() - Method in class org.apache.avro.io.JsonDecoder
 
readDouble() - Method in class org.apache.avro.io.ResolvingDecoder
 
readDouble() - Method in class org.apache.avro.io.ValidatingDecoder
 
readEnum(Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read an enum value.
readEnum() - Method in class org.apache.avro.io.BinaryDecoder
 
readEnum() - Method in class org.apache.avro.io.Decoder
Reads an enumeration.
readEnum() - Method in class org.apache.avro.io.JsonDecoder
 
readEnum() - Method in class org.apache.avro.io.ResolvingDecoder
 
readEnum() - Method in class org.apache.avro.io.ValidatingDecoder
 
reader - Variable in class org.apache.avro.io.parsing.Symbol.ResolvingAction
 
READER_WRITER_COMPATIBLE_MESSAGE - Static variable in class org.apache.avro.SchemaCompatibility
Message to annotate reader/writer schema pairs that are compatible.
readError(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.generic.GenericRequestor
 
readError(Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
Deprecated.
readError(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
Reads an error message.
readError(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
 
readField(Object, Schema.Field, Object, ResolvingDecoder, Object) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read a single field of a record.
readField(Object, Schema.Field, Object, ResolvingDecoder, Object) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
readFieldOrder() - Method in class org.apache.avro.io.ResolvingDecoder
Returns the actual order in which the reader's fields will be returned to the reader.
readFixed(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read a fixed value.
readFixed(byte[], int, int) - Method in class org.apache.avro.io.BinaryDecoder
 
readFixed(byte[], int, int) - Method in class org.apache.avro.io.Decoder
Reads fixed sized binary object.
readFixed(byte[]) - Method in class org.apache.avro.io.Decoder
A shorthand for readFixed(bytes, 0, bytes.length).
readFixed(byte[], int, int) - Method in class org.apache.avro.io.JsonDecoder
 
readFixed(byte[], int, int) - Method in class org.apache.avro.io.ValidatingDecoder
 
readFloat() - Method in class org.apache.avro.io.BinaryDecoder
 
readFloat() - Method in class org.apache.avro.io.Decoder
Reads a float written by Encoder.writeFloat(float).
readFloat() - Method in class org.apache.avro.io.JsonDecoder
 
readFloat() - Method in class org.apache.avro.io.ResolvingDecoder
 
readFloat() - Method in class org.apache.avro.io.ValidatingDecoder
 
readIndex() - Method in class org.apache.avro.io.BinaryDecoder
 
readIndex() - Method in class org.apache.avro.io.Decoder
Reads the tag of a union written by Encoder.writeIndex(int).
readIndex() - Method in class org.apache.avro.io.JsonDecoder
 
readIndex() - Method in class org.apache.avro.io.ResolvingDecoder
 
readIndex() - Method in class org.apache.avro.io.ValidatingDecoder
 
readInt(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read integers.
readInt() - Method in class org.apache.avro.io.BinaryDecoder
 
readInt() - Method in class org.apache.avro.io.Decoder
Reads an integer written by Encoder.writeInt(int).
readInt() - Method in class org.apache.avro.io.JsonDecoder
 
readInt() - Method in class org.apache.avro.io.ValidatingDecoder
 
readInt(Object, Schema, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
readInt(Object, Schema, Decoder) - Method in class org.apache.avro.thrift.ThriftDatumReader
 
readLong() - Method in class org.apache.avro.io.BinaryDecoder
 
readLong() - Method in class org.apache.avro.io.Decoder
Reads a long written by Encoder.writeLong(long).
readLong() - Method in class org.apache.avro.io.JsonDecoder
 
readLong() - Method in class org.apache.avro.io.ResolvingDecoder
 
readLong() - Method in class org.apache.avro.io.ValidatingDecoder
 
readMap(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read a map instance.
readMapKey(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
readMapStart() - Method in class org.apache.avro.io.BinaryDecoder
 
readMapStart() - Method in class org.apache.avro.io.Decoder
Reads and returns the size of the next block of map-entries.
readMapStart() - Method in class org.apache.avro.io.JsonDecoder
 
readMapStart() - Method in class org.apache.avro.io.ValidatingDecoder
 
readNull() - Method in class org.apache.avro.io.BinaryDecoder
 
readNull() - Method in class org.apache.avro.io.Decoder
"Reads" a null value.
readNull() - Method in class org.apache.avro.io.JsonDecoder
 
readNull() - Method in class org.apache.avro.io.ValidatingDecoder
 
readRecord(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read a record instance.
readRecord(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.protobuf.ProtobufDatumReader
 
readRequest(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.generic.GenericResponder
 
readRequest(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.Responder
Reads a request message.
readResponse(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.generic.GenericRequestor
 
readResponse(Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
Deprecated.
readResponse(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
Reads a response message.
readResponse(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
 
readString(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read strings.
readString(Object, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
Called to read strings.
readString(Utf8) - Method in class org.apache.avro.io.BinaryDecoder
 
readString() - Method in class org.apache.avro.io.BinaryDecoder
 
readString(Utf8) - Method in class org.apache.avro.io.Decoder
Reads a char-string written by Encoder.writeString(org.apache.avro.util.Utf8).
readString() - Method in class org.apache.avro.io.Decoder
Reads a char-string written by Encoder.writeString(org.apache.avro.util.Utf8).
readString(Utf8) - Method in class org.apache.avro.io.JsonDecoder
 
readString() - Method in class org.apache.avro.io.JsonDecoder
 
readString(Utf8) - Method in class org.apache.avro.io.ValidatingDecoder
 
readString() - Method in class org.apache.avro.io.ValidatingDecoder
 
readString(Object, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
 
RecodecTool - Class in org.apache.avro.tool
Tool to alter the codec of an Avro data file.
RecodecTool() - Constructor for class org.apache.avro.tool.RecodecTool
 
RECORD - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
record(String) - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build an Avro record type.
record(String) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build an Avro record type.
record(String) - Static method in class org.apache.avro.SchemaBuilder
Create a builder for an Avro record with the specified name.
record(String) - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build an Avro record type.
RECORD_END - Static variable in class org.apache.avro.io.parsing.Symbol
 
RECORD_START - Static variable in class org.apache.avro.io.parsing.Symbol
 
RecordBuilder<T> - Interface in org.apache.avro.data
Interface for record builders
RecordBuilderBase<T extends IndexedRecord> - Class in org.apache.avro.data
Abstract base class for RecordBuilder implementations.
RecordBuilderBase(Schema, GenericData) - Constructor for class org.apache.avro.data.RecordBuilderBase
Creates a RecordBuilderBase for building records of the given type.
RecordBuilderBase(RecordBuilderBase<T>, GenericData) - Constructor for class org.apache.avro.data.RecordBuilderBase
RecordBuilderBase copy constructor.
RecordDeclaration() - Method in class org.apache.avro.compiler.idl.Idl
 
recordDefault(GenericRecord) - Method in class org.apache.avro.SchemaBuilder.RecordDefault
Completes this field with the default value provided, cannot be null
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.
ReferenceType() - Method in class org.apache.avro.compiler.idl.Idl
A reference to some other existing type
ReflectData - Class in org.apache.avro.reflect
Utilities to use existing Java classes and interfaces via reflection.
ReflectData() - Constructor for class org.apache.avro.reflect.ReflectData
For subclasses.
ReflectData(ClassLoader) - Constructor for class org.apache.avro.reflect.ReflectData
Construct with a particular classloader.
ReflectData.AllowNull - Class in org.apache.avro.reflect
ReflectData implementation that permits null field values.
ReflectData.AllowNull() - Constructor for class org.apache.avro.reflect.ReflectData.AllowNull
 
ReflectDatumReader<T> - Class in org.apache.avro.reflect
DatumReader for existing classes via Java reflection.
ReflectDatumReader() - Constructor for class org.apache.avro.reflect.ReflectDatumReader
 
ReflectDatumReader(Class<T>) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
Construct for reading instances of a class.
ReflectDatumReader(Schema) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
Construct where the writer's and reader's schemas are the same.
ReflectDatumReader(Schema, Schema) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
Construct given writer's and reader's schema.
ReflectDatumReader(Schema, Schema, ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
Construct given writer's and reader's schema and the data model.
ReflectDatumReader(ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
Construct given a ReflectData.
ReflectDatumWriter<T> - Class in org.apache.avro.reflect
DatumWriter for existing classes via Java reflection.
ReflectDatumWriter() - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
 
ReflectDatumWriter(Class<T>) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
 
ReflectDatumWriter(Class<T>, ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
 
ReflectDatumWriter(Schema) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
 
ReflectDatumWriter(Schema, ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
 
ReflectDatumWriter(ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
 
ReflectRequestor - Class in org.apache.avro.ipc.reflect
A Requestor for existing interfaces.
ReflectRequestor(Class<?>, Transceiver) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
 
ReflectRequestor(Protocol, Transceiver) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
 
ReflectRequestor(Class<?>, Transceiver, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
 
ReflectRequestor(Protocol, Transceiver, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
 
ReflectResponder - Class in org.apache.avro.ipc.reflect
Responder for existing interfaces.
ReflectResponder(Class, Object) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
 
ReflectResponder(Protocol, Object) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
 
ReflectResponder(Class, Object, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
 
ReflectResponder(Protocol, Object, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
 
ReInit(InputStream) - Method in class org.apache.avro.compiler.idl.Idl
Reinitialise.
ReInit(InputStream, String) - Method in class org.apache.avro.compiler.idl.Idl
Reinitialise.
ReInit(Reader) - Method in class org.apache.avro.compiler.idl.Idl
Reinitialise.
ReInit(IdlTokenManager) - Method in class org.apache.avro.compiler.idl.Idl
Reinitialise.
ReInit(JavaCharStream) - Method in class org.apache.avro.compiler.idl.IdlTokenManager
Reinitialise parser.
ReInit(JavaCharStream, int) - Method in class org.apache.avro.compiler.idl.IdlTokenManager
Reinitialise parser.
ReInit(Reader, int, int, int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(Reader, int, int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(Reader) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(InputStream, String, int, int, int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(InputStream, int, int, int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(InputStream, String, int, int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(InputStream, int, int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(InputStream, String) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
ReInit(InputStream) - Method in class org.apache.avro.compiler.idl.JavaCharStream
Reinitialise.
rejectedSpans - Variable in class org.apache.avro.ipc.trace.SpanAggregator.TraceFormationResults
Spans which did not describe a complete trace.
remove() - Method in class org.apache.avro.file.DataFileReader12
 
remove() - Method in class org.apache.avro.file.DataFileStream
Not supported.
remove(int) - Method in class org.apache.avro.generic.GenericData.Array
 
remove() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
remove() - Method in class org.apache.avro.mapred.SequenceFileReader
 
remove(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
 
remove() - Method in class org.apache.trevni.avro.AvroColumnReader
 
remove() - Method in class org.apache.trevni.ColumnValues
 
request(String, Object) - Method in class org.apache.avro.ipc.generic.GenericRequestor
 
request(String, Object, Callback<T>) - Method in class org.apache.avro.ipc.generic.GenericRequestor
 
request(String, Object) - Method in class org.apache.avro.ipc.Requestor
Writes a request message and reads a response or error message.
request(String, Object, Callback<T>) - Method in class org.apache.avro.ipc.Requestor
Writes a request message and returns the result through a Callback.
requestCallMeta - Variable in class org.apache.avro.ipc.RPCContext
 
requestCallMeta() - Method in class org.apache.avro.ipc.RPCContext
This is an access method for the per-call state provided by the client to the server.
requestHandshakeMeta() - Method in class org.apache.avro.ipc.RPCContext
This is an access method for the handshake state provided by the client to the server.
Requestor - Class in org.apache.avro.ipc
Base class for the client side of a protocol interaction.
Requestor(Protocol, Transceiver) - Constructor for class org.apache.avro.ipc.Requestor
 
Requestor.TransceiverCallback<T> - Class in org.apache.avro.ipc
Handles callbacks from transceiver invocations.
Requestor.TransceiverCallback(Requestor.Request, Callback<T>) - Constructor for class org.apache.avro.ipc.Requestor.TransceiverCallback
Creates a TransceiverCallback.
requestorHostname - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
requestPayloadSize - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
requiredBoolean(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a boolean field with the given name and no default.
requiredBytes(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a bytes field with the given name and no default.
requiredDouble(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a double field with the given name and no default.
requiredFloat(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a float field with the given name and no default.
requiredInt(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating an int field with the given name and no default.
requiredLong(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a long field with the given name and no default.
requiredString(String) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
Shortcut for creating a string field with the given name and no default.
reset() - Method in class org.apache.avro.io.parsing.Parser
 
reset() - Method in class org.apache.avro.util.ByteBufferOutputStream
 
resolve(Schema, Schema) - Static method in class org.apache.avro.io.ResolvingDecoder
Produces an opaque resolver that can be used to construct a new ResolvingDecoder.ResolvingDecoder(Object, Decoder).
resolveUnion(Schema, Object) - Method in class org.apache.avro.generic.GenericData
Return the index for a datum within a union.
resolveUnion(Schema, Object) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to find the index for a datum within a union.
resolvingDecoder(Schema, Schema, Decoder) - Method in class org.apache.avro.io.DecoderFactory
Creates a ResolvingDecoder wrapping the Decoder provided.
ResolvingDecoder - Class in org.apache.avro.io
Decoder that performs type-resolution between the reader's and writer's schemas.
ResolvingGrammarGenerator - Class in org.apache.avro.io.parsing
The class that generates a resolving grammar to resolve between two schemas.
ResolvingGrammarGenerator() - Constructor for class org.apache.avro.io.parsing.ResolvingGrammarGenerator
 
respond(List<ByteBuffer>) - Method in class org.apache.avro.ipc.Responder
Called by a server to deserialize a request, compute and serialize a response or error.
respond(List<ByteBuffer>, Transceiver) - Method in class org.apache.avro.ipc.Responder
Called by a server to deserialize a request, compute and serialize a response or error.
respond(Protocol.Message, Object) - Method in class org.apache.avro.ipc.Responder
Computes the response for a message.
respond(Protocol.Message, Object) - Method in class org.apache.avro.ipc.specific.SpecificResponder
 
Responder - Class in org.apache.avro.ipc
Base class for the server side of a protocol interaction.
Responder(Protocol) - Constructor for class org.apache.avro.ipc.Responder
 
responder - Variable in class org.apache.avro.ipc.trace.TracePlugin
 
responderHostname - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
ResponderServlet - Class in org.apache.avro.ipc
An HttpServlet that responds to Avro RPC requests.
ResponderServlet(Responder) - Constructor for class org.apache.avro.ipc.ResponderServlet
 
response - Variable in class org.apache.avro.ipc.RPCContext
 
response() - Method in class org.apache.avro.ipc.RPCContext
The response object generated at the server, if it exists.
responseCallMeta - Variable in class org.apache.avro.ipc.RPCContext
 
responseCallMeta() - Method in class org.apache.avro.ipc.RPCContext
This is an access method for the per-call state provided by the server back to the client.
responseHandshakeMeta() - Method in class org.apache.avro.ipc.RPCContext
This is an access method for the handshake state provided by the server back to the client
responsePayloadSize - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
ResultType() - Method in class org.apache.avro.compiler.idl.Idl
Result types are like other types, except we provide "void" as an alias of "null"
reverse() - Method in interface org.apache.avro.generic.GenericArray
Reverses the order of the elements in this array.
reverse() - Method in class org.apache.avro.generic.GenericData.Array
 
rindex - Variable in class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
 
rindex - Variable in class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
 
RPAREN - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
RPCContext - Class in org.apache.avro.ipc
This class represents the context of an RPC call or RPC handshake.
RPCContext() - Constructor for class org.apache.avro.ipc.RPCContext
 
rpcMetaPlugins - Variable in class org.apache.avro.ipc.Requestor
 
rpcMetaPlugins - Variable in class org.apache.avro.ipc.Responder
 
RPCPlugin - Class in org.apache.avro.ipc
An instrumentation API for RPC metadata.
RPCPlugin() - Constructor for class org.apache.avro.ipc.RPCPlugin
 
RpcProtocolTool - Class in org.apache.avro.tool
Tool to grab the protocol from a remote running service.
RpcProtocolTool() - Constructor for class org.apache.avro.tool.RpcProtocolTool
 
RpcReceiveTool - Class in org.apache.avro.tool
Receives one RPC call and responds.
RpcReceiveTool() - Constructor for class org.apache.avro.tool.RpcReceiveTool
 
RpcSendTool - Class in org.apache.avro.tool
Sends a single RPC message.
RpcSendTool() - Constructor for class org.apache.avro.tool.RpcSendTool
 
run() - Method in class org.apache.avro.ipc.DatagramServer
 
run() - Method in class org.apache.avro.ipc.SocketServer
Deprecated.
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.BinaryFragmentToJsonTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.CatTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.ConcatTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.CreateRandomFileTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.DataFileGetMetaTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.DataFileGetSchemaTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.DataFileReadTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.DataFileWriteTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.FromTextTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.IdlTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.IdlToSchemataTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.InduceSchemaTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.JsonToBinaryFragmentTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.RecodecTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.RpcProtocolTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.RpcReceiveTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.RpcSendTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.SpecificCompilerTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.TetherTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in interface org.apache.avro.tool.Tool
Runs the tool with supplied arguments.
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.ToTextTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.ToTrevniTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.TrevniCreateRandomTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.TrevniMetadataTool
 
run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.TrevniToJsonTool
 
runJob(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
Submit a job to the map/reduce cluster.

S

SaslSocketServer - Class in org.apache.avro.ipc
A Server that uses javax.security.sasl for authentication and encryption.
SaslSocketServer(Responder, SocketAddress) - Constructor for class org.apache.avro.ipc.SaslSocketServer
Create using SASL's anonymous (RFC 2245) mechanism.
SaslSocketServer(Responder, SocketAddress, String, String, String, Map<String, ?>, CallbackHandler) - Constructor for class org.apache.avro.ipc.SaslSocketServer
Create using the specified SaslServer parameters.
SaslSocketTransceiver - Class in org.apache.avro.ipc
A Transceiver that uses javax.security.sasl for authentication and encryption.
SaslSocketTransceiver(SocketAddress) - Constructor for class org.apache.avro.ipc.SaslSocketTransceiver
Create using SASL's anonymous (RFC 2245) mechanism.
SaslSocketTransceiver(SocketAddress, SaslClient) - Constructor for class org.apache.avro.ipc.SaslSocketTransceiver
Create using the specified SaslClient.
SaslSocketTransceiver(SocketChannel, SaslServer) - Constructor for class org.apache.avro.ipc.SaslSocketTransceiver
Create using the specified SaslServer.
SCHEMA - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
SCHEMA - Static variable in class org.apache.avro.data.Json
The schema for Json data.
schema() - Method in class org.apache.avro.data.RecordBuilderBase
 
SCHEMA - Static variable in class org.apache.avro.file.DataFileConstants
 
schema - Variable in class org.apache.avro.reflect.CustomEncoding
 
Schema - Class in org.apache.avro
An abstract data type.
schema() - Method in class org.apache.avro.Schema.Field
This field's Schema.
schema - Variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
Provided avro schema from the context
SCHEMA$ - Static variable in enum org.apache.avro.ipc.HandshakeMatch
 
SCHEMA$ - Static variable in class org.apache.avro.ipc.HandshakeRequest
 
SCHEMA$ - Static variable in class org.apache.avro.ipc.HandshakeResponse
 
SCHEMA$ - Static variable in class org.apache.avro.ipc.MD5
 
SCHEMA$ - Static variable in class org.apache.avro.ipc.trace.ID
 
SCHEMA$ - Static variable in class org.apache.avro.ipc.trace.Span
 
SCHEMA$ - Static variable in enum org.apache.avro.ipc.trace.SpanEvent
 
SCHEMA$ - Static variable in class org.apache.avro.ipc.trace.TimestampedEvent
 
SCHEMA$ - Static variable in enum org.apache.avro.mapred.tether.TaskType
 
Schema.Field - Class in org.apache.avro
A field within a record.
Schema.Field(String, Schema, String, JsonNode) - Constructor for class org.apache.avro.Schema.Field
 
Schema.Field(String, Schema, String, JsonNode, Schema.Field.Order) - Constructor for class org.apache.avro.Schema.Field
 
Schema.Field.Order - Enum in org.apache.avro
How values of this field should be ordered when sorting records.
Schema.Parser - Class in org.apache.avro
A parser for JSON-format schemas.
Schema.Parser() - Constructor for class org.apache.avro.Schema.Parser
 
Schema.Type - Enum in org.apache.avro
The type of a schema.
SCHEMA_KEY - Static variable in class org.apache.trevni.avro.AvroColumnWriter
 
SchemaBuilder - Class in org.apache.avro
A fluent interface for building Schema instances.
SchemaBuilder.ArrayBuilder<R> - Class in org.apache.avro
Builds an Avro Array type with optional properties.
SchemaBuilder.ArrayBuilder(SchemaBuilder.Completion<R>, SchemaBuilder.NameContext) - Constructor for class org.apache.avro.SchemaBuilder.ArrayBuilder
 
SchemaBuilder.ArrayDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.BaseFieldTypeBuilder<R> - Class in org.apache.avro
A special Builder for Record fields.
SchemaBuilder.BaseFieldTypeBuilder(SchemaBuilder.FieldBuilder<R>, SchemaBuilder.CompletionWrapper) - Constructor for class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
 
SchemaBuilder.BaseTypeBuilder<R> - Class in org.apache.avro
A common API for building types within a context.
SchemaBuilder.BooleanBuilder<R> - Class in org.apache.avro
Builds an Avro boolean type with optional properties.
SchemaBuilder.BooleanDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.BytesBuilder<R> - Class in org.apache.avro
Builds an Avro bytes type with optional properties.
SchemaBuilder.BytesDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.DoubleBuilder<R> - Class in org.apache.avro
Builds an Avro double type with optional properties.
SchemaBuilder.DoubleDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.EnumBuilder<R> - Class in org.apache.avro
Builds an Avro Enum type with optional properties, namespace, doc, and aliases.
SchemaBuilder.EnumDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.FieldAssembler<R> - Class in org.apache.avro
 
SchemaBuilder.FieldBuilder<R> - Class in org.apache.avro
Builds a Field in the context of a SchemaBuilder.FieldAssembler.
SchemaBuilder.FieldDefault<R,S extends SchemaBuilder.FieldDefault<R,S>> - Class in org.apache.avro
Abstract base class for field defaults.
SchemaBuilder.FieldTypeBuilder<R> - Class in org.apache.avro
SchemaBuilder.FixedBuilder<R> - Class in org.apache.avro
Builds an Avro Fixed type with optional properties, namespace, doc, and aliases.
SchemaBuilder.FixedDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.FloatBuilder<R> - Class in org.apache.avro
Builds an Avro float type with optional properties.
SchemaBuilder.FloatDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.GenericDefault<R> - Class in org.apache.avro
 
SchemaBuilder.IntBuilder<R> - Class in org.apache.avro
Builds an Avro int type with optional properties.
SchemaBuilder.IntDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.LongBuilder<R> - Class in org.apache.avro
Builds an Avro long type with optional properties.
SchemaBuilder.LongDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.MapBuilder<R> - Class in org.apache.avro
Builds an Avro Map type with optional properties.
SchemaBuilder.MapDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.NamedBuilder<S extends SchemaBuilder.NamedBuilder<S>> - Class in org.apache.avro
An abstract type that provides builder methods for configuring the name, doc, and aliases of all Avro types that have names (fields, Fixed, Record, and Enum).
SchemaBuilder.NamedBuilder(SchemaBuilder.NameContext, String) - Constructor for class org.apache.avro.SchemaBuilder.NamedBuilder
 
SchemaBuilder.NamespacedBuilder<R,S extends SchemaBuilder.NamespacedBuilder<R,S>> - Class in org.apache.avro
An abstract type that provides builder methods for configuring the namespace for all Avro types that have namespaces (Fixed, Record, and Enum).
SchemaBuilder.NamespacedBuilder(SchemaBuilder.Completion<R>, SchemaBuilder.NameContext, String) - Constructor for class org.apache.avro.SchemaBuilder.NamespacedBuilder
 
SchemaBuilder.NullBuilder<R> - Class in org.apache.avro
Builds an Avro null type with optional properties.
SchemaBuilder.NullDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.PropBuilder<S extends SchemaBuilder.PropBuilder<S>> - Class in org.apache.avro
An abstract builder for all Avro types.
SchemaBuilder.PropBuilder() - Constructor for class org.apache.avro.SchemaBuilder.PropBuilder
 
SchemaBuilder.RecordBuilder<R> - Class in org.apache.avro
 
SchemaBuilder.RecordDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.StringBldr<R> - Class in org.apache.avro
Builds an Avro string type with optional properties.
SchemaBuilder.StringDefault<R> - Class in org.apache.avro
Choose whether to use a default value for the field or not.
SchemaBuilder.TypeBuilder<R> - Class in org.apache.avro
A Builder for creating any Avro schema type.
SchemaBuilder.UnionAccumulator<R> - Class in org.apache.avro
Accumulates all of the types in a union.
SchemaBuilder.UnionFieldTypeBuilder<R> - Class in org.apache.avro
Builder for a union field.
SchemaBuilderException - Exception in org.apache.avro
Thrown for errors building schemas.
SchemaBuilderException(Throwable) - Constructor for exception org.apache.avro.SchemaBuilderException
 
SchemaBuilderException(String) - Constructor for exception org.apache.avro.SchemaBuilderException
 
SchemaCompatibility - Class in org.apache.avro
Evaluate the compatibility between a reader schema and a writer schema.
SchemaCompatibility.SchemaCompatibilityType - Enum in org.apache.avro
Identifies the type of a schema compatibility result.
SchemaCompatibility.SchemaPairCompatibility - Class in org.apache.avro
Provides information about the compatibility of a single reader and writer schema pair.
SchemaCompatibility.SchemaPairCompatibility(SchemaCompatibility.SchemaCompatibilityType, Schema, Schema, String) - Constructor for class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
Constructs a new instance.
SchemaMojo - Class in org.apache.avro.mojo
Generate Java classes from Avro schema files (.avsc)
SchemaMojo() - Constructor for class org.apache.avro.mojo.SchemaMojo
 
schemaNameEquals(Schema, Schema) - Static method in class org.apache.avro.SchemaCompatibility
Tests the equality of two Avro named schemas.
SchemaNormalization - Class in org.apache.avro
Collection of static methods for generating the cannonical form of schemas (see SchemaNormalization.toParsingForm(org.apache.avro.Schema)) -- and fingerprints of cannonical forms (SchemaNormalization.fingerprint(java.lang.String, byte[])).
SchemaParseException - Exception in org.apache.avro
Thrown for errors parsing schemas and protocols.
SchemaParseException(Throwable) - Constructor for exception org.apache.avro.SchemaParseException
 
SchemaParseException(String) - Constructor for exception org.apache.avro.SchemaParseException
 
SchemaProperty(Map<String, JsonNode>) - Method in class org.apache.avro.compiler.idl.Idl
 
SchemaTask - Class in org.apache.avro.compiler.specific
Ant task to generate Java interface and classes for a protocol.
SchemaTask() - Constructor for class org.apache.avro.compiler.specific.SchemaTask
 
seek(long) - Method in class org.apache.avro.file.DataFileReader
Move to a specific, known synchronization point, one returned from DataFileWriter.sync() while writing.
seek(long) - Method in class org.apache.avro.file.DataFileReader12
Move to the specified synchronization point, as returned by DataFileWriter.sync().
seek(long) - Method in class org.apache.avro.file.SeekableByteArrayInput
 
seek(long) - Method in class org.apache.avro.file.SeekableFileInput
 
seek(long) - Method in interface org.apache.avro.file.SeekableInput
Set the position for the next read().
seek(long) - Method in class org.apache.avro.mapred.FsInput
 
seek(long) - Method in class org.apache.trevni.ColumnValues
Seek to the named row.
seek(T) - Method in class org.apache.trevni.ColumnValues
Seek to the named value.
SeekableByteArrayInput - Class in org.apache.avro.file
A SeekableInput backed with data in a byte array.
SeekableByteArrayInput(byte[]) - Constructor for class org.apache.avro.file.SeekableByteArrayInput
 
SeekableFileInput - Class in org.apache.avro.file
A FileInputStream that implements SeekableInput.
SeekableFileInput(File) - Constructor for class org.apache.avro.file.SeekableFileInput
 
SeekableFileInput(FileDescriptor) - Constructor for class org.apache.avro.file.SeekableFileInput
 
SeekableInput - Interface in org.apache.avro.file
An InputStream that supports seek and tell.
self() - Method in class org.apache.avro.SchemaBuilder.ArrayBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.BooleanBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.BytesBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.DoubleBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.EnumBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.FixedBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.FloatBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.IntBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.LongBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.MapBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.NullBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.PropBuilder
a self-type for chaining builder subclasses.
self() - Method in class org.apache.avro.SchemaBuilder.RecordBuilder
 
self() - Method in class org.apache.avro.SchemaBuilder.StringBldr
 
SEMICOLON - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
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
Server - Interface in org.apache.avro.ipc
A server listening on a port.
serverConnecting(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
Called on the server during the RPC handshake
serverConnecting(RPCContext) - Method in class org.apache.avro.ipc.trace.TracePlugin
 
serverHash - Variable in class org.apache.avro.ipc.HandshakeRequest
Deprecated.
serverHash - Variable in class org.apache.avro.ipc.HandshakeResponse
Deprecated.
serverProtocol - Variable in class org.apache.avro.ipc.HandshakeResponse
Deprecated.
serverReceiveRequest(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
This method is invoked at the RPC server when the request is received, but before the call itself is executed
serverReceiveRequest(RPCContext) - Method in class org.apache.avro.ipc.stats.StatsPlugin
 
serverReceiveRequest(RPCContext) - Method in class org.apache.avro.ipc.trace.TracePlugin
 
serverSendResponse(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
This method is invoked at the server before the response is executed, but before the response has been formulated
serverSendResponse(RPCContext) - Method in class org.apache.avro.ipc.stats.StatsPlugin
 
serverSendResponse(RPCContext) - Method in class org.apache.avro.ipc.trace.TracePlugin
 
set(int, T) - Method in class org.apache.avro.generic.GenericData.Array
 
set(String, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
Sets the value of a field.
set(Schema.Field, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
Sets the value of a field.
set(int, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
Sets the value of a field.
set(K, V) - Method in class org.apache.avro.mapred.Pair
Set both the key and value.
set(String) - Method in class org.apache.avro.util.Utf8
Set to the contents of a String.
set(String, byte[]) - Method in class org.apache.trevni.MetaData
Set a metadata property to a binary value.
set(String, String) - Method in class org.apache.trevni.MetaData
Set a metadata property to a String value.
set(String, long) - Method in class org.apache.trevni.MetaData
Set a metadata property to a long value.
setByteLength(int) - Method in class org.apache.avro.util.Utf8
Set length in bytes.
setCause(Throwable) - Method in interface org.apache.avro.data.ErrorBuilder
Sets the error cause
setCause(Throwable) - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
setChecksum(String) - Method in class org.apache.trevni.MetaData
Set the checksum algorithm name.
setClientHash(MD5) - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Sets the value of the 'clientHash' field
setClientHash(MD5) - Method in class org.apache.avro.ipc.HandshakeRequest
Sets the value of the 'clientHash' field.
setClientProtocol(String) - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Sets the value of the 'clientProtocol' field
setClientProtocol(String) - Method in class org.apache.avro.ipc.HandshakeRequest
Sets the value of the 'clientProtocol' field.
setCodec(CodecFactory) - Method in class org.apache.avro.file.DataFileWriter
Configures this writer to use the given codec.
setCodec(String) - Method in class org.apache.trevni.MetaData
Set the compression codec name.
setCombinerClass(JobConf, Class<? extends AvroReducer>) - Static method in class org.apache.avro.mapred.AvroJob
Configure a job's combiner implementation.
setComplete(boolean) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'complete' field
setComplete(Boolean) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'complete' field.
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.
setCreateSetters(boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Set to false to not create setter methods for the fields of the record.
setDataModelClass(Configuration, Class<? extends GenericData>) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
Sets the data model class for de/seralization.
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.
setDatas(List<ByteBuffer>) - Method in class org.apache.avro.ipc.NettyTransportCodec.NettyDataPack
 
setDebugStream(PrintStream) - Method in class org.apache.avro.compiler.idl.IdlTokenManager
Set debug output.
setDeflateLevel(JobConf, int) - Static method in class org.apache.avro.mapred.AvroOutputFormat
Enable output compression using the deflate codec and specify its level.
setDestdir(File) - Method in class org.apache.avro.compiler.specific.ProtocolTask
Set the output directory
setEvent(Object) - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Sets the value of the 'event' field
setEvent(Object) - Method in class org.apache.avro.ipc.trace.TimestampedEvent
Sets the value of the 'event' field.
setEvents(List<TimestampedEvent>) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'events' field
setEvents(List<TimestampedEvent>) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'events' field.
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).
setExpected(Schema) - Method in class org.apache.avro.generic.GenericDatumReader
Set the reader's schema.
setField(Object, String, int, Object) - Method in class org.apache.avro.generic.GenericData
setField(Object, String, int, Object, Object) - Method in class org.apache.avro.generic.GenericData
setField(Object, String, int, Object) - Method in class org.apache.avro.protobuf.ProtobufData
 
setField(Object, String, int, Object, Object) - Method in class org.apache.avro.protobuf.ProtobufData
 
setField(Object, String, int, Object) - Method in class org.apache.avro.reflect.ReflectData
 
setField(Object, String, int, Object, Object) - Method in class org.apache.avro.reflect.ReflectData
 
setField(Object, String, int, Object) - Method in class org.apache.avro.thrift.ThriftData
 
setField(Object, String, int, Object, Object) - Method in class org.apache.avro.thrift.ThriftData
 
setFields(List<Schema.Field>) - Method in class org.apache.avro.Schema
If this is a record, set its fields.
setFieldVisibility(SpecificCompiler.FieldVisibility) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Sets the field visibility option.
setFile(File) - Method in class org.apache.avro.compiler.specific.ProtocolTask
Set the schema file.
setFlushOnEveryBlock(boolean) - Method in class org.apache.avro.file.DataFileWriter
Set whether this writer should flush the block to the stream every time a sync marker is written.
setHandshakeRequest(HandshakeRequest) - Method in class org.apache.avro.ipc.RPCContext
Set the handshake request of this RPC.
setHandshakeResponse(HandshakeResponse) - Method in class org.apache.avro.ipc.RPCContext
Set the handshake response of this RPC.
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.
setItemCount(long) - Method in class org.apache.avro.io.BinaryEncoder
 
setItemCount(long) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
setItemCount(long) - Method in class org.apache.avro.io.Encoder
Call this method before writing a batch of items in an array or a map.
setItemCount(long) - Method in class org.apache.avro.io.ParsingEncoder
 
setItemCount(long) - Method in class org.apache.avro.io.ValidatingEncoder
 
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.
setLength(int) - Method in class org.apache.avro.util.Utf8
Deprecated.
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.
setMatch(HandshakeMatch) - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Sets the value of the 'match' field
setMatch(HandshakeMatch) - Method in class org.apache.avro.ipc.HandshakeResponse
Sets the value of the 'match' field.
setMaxSpans(long) - Method in class org.apache.avro.ipc.trace.FileSpanStorage
 
setMaxSpans(long) - Method in class org.apache.avro.ipc.trace.InMemorySpanStorage
 
setMaxSpans(long) - Method in interface org.apache.avro.ipc.trace.SpanStorage
Set the maximum number of spans to have in storage at any given time.
setMessage(Protocol.Message) - Method in class org.apache.avro.ipc.RPCContext
Sets the Protocol.Message corresponding to this RPC
setMessageName(String) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'messageName' field
setMessageName(String) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'messageName' field.
setMeta(String, byte[]) - Method in class org.apache.avro.file.DataFileWriter
Set a metadata property.
setMeta(String, String) - Method in class org.apache.avro.file.DataFileWriter
Set a metadata property.
setMeta(String, long) - Method in class org.apache.avro.file.DataFileWriter
Set a metadata property.
setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Sets the value of the 'meta' field
setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeRequest
Sets the value of the 'meta' field.
setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Sets the value of the 'meta' field
setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeResponse
Sets the value of the 'meta' field.
setMeta(JobConf, String, String) - Static method in class org.apache.trevni.avro.AvroTrevniOutputFormat
Add metadata to job output files.
setModel(GenericData) - Method in class org.apache.trevni.avro.AvroColumnReader.Params
Set data representation.
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.
setParent(ColumnMetaData) - Method in class org.apache.trevni.ColumnMetaData
Set this column's parent.
setParentSpanID(ID) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'parentSpanID' field
setParentSpanID(ID) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'parentSpanID' field.
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.
setRemote(Protocol) - Method in class org.apache.avro.ipc.NettyTransceiver
 
setRemote(Protocol) - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
setRemote(Protocol) - Method in class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
setRemote(Protocol) - Method in class org.apache.avro.ipc.Transceiver
Called with the remote protocol when a handshake has been completed.
setRequestorHostname(String) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'requestorHostname' field
setRequestorHostname(String) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'requestorHostname' field.
setRequestPayload(List<ByteBuffer>) - Method in class org.apache.avro.ipc.RPCContext
Sets the serialized payload of the request in this RPC.
setRequestPayloadSize(long) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'requestPayloadSize' field
setRequestPayloadSize(Long) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'requestPayloadSize' field.
setResponderHostname(String) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'responderHostname' field
setResponderHostname(String) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'responderHostname' field.
setResponsePayload(List<ByteBuffer>) - Method in class org.apache.avro.ipc.RPCContext
Sets the serialized payload of the response in this RPC.
setResponsePayloadSize(long) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'responsePayloadSize' field
setResponsePayloadSize(Long) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'responsePayloadSize' field.
setSchema(Schema) - Method in class org.apache.avro.data.Json.Reader
 
setSchema(Schema) - Method in class org.apache.avro.data.Json.Writer
 
setSchema(Schema) - Method in class org.apache.avro.generic.GenericData.Fixed
 
setSchema(Schema) - Method in class org.apache.avro.generic.GenericDatumReader
 
setSchema(Schema) - Method in class org.apache.avro.generic.GenericDatumWriter
 
setSchema(Schema) - Method in interface org.apache.avro.io.DatumReader
Set the writer's schema.
setSchema(Schema) - Method in interface org.apache.avro.io.DatumWriter
Set the schema.
setSchema(Schema) - Method in class org.apache.avro.specific.SpecificDatumReader
 
setSchema(Schema) - Method in class org.apache.trevni.avro.AvroColumnReader.Params
Set subset schema to project data down to.
setSerial(int) - Method in class org.apache.avro.ipc.NettyTransportCodec.NettyDataPack
 
setServerHash(MD5) - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
Sets the value of the 'serverHash' field
setServerHash(MD5) - Method in class org.apache.avro.ipc.HandshakeRequest
Sets the value of the 'serverHash' field.
setServerHash(MD5) - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Sets the value of the 'serverHash' field
setServerHash(MD5) - Method in class org.apache.avro.ipc.HandshakeResponse
Sets the value of the 'serverHash' field.
setServerProtocol(String) - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
Sets the value of the 'serverProtocol' field
setServerProtocol(String) - Method in class org.apache.avro.ipc.HandshakeResponse
Sets the value of the 'serverProtocol' field.
setSpanID(ID) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'spanID' field
setSpanID(ID) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'spanID' field.
setStringType(GenericData.StringType) - Method in class org.apache.avro.compiler.specific.ProtocolTask
Set the string type.
setStringType(GenericData.StringType) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Set the Java type to be emitted for string schemas.
setStringType(Schema, GenericData.StringType) - Static method in class org.apache.avro.generic.GenericData
Set the Java type to be used when reading this schema.
setSyncInterval(int) - Method in class org.apache.avro.file.DataFileWriter
Set the synchronization interval for this file, in bytes.
setSyncInterval(JobConf, int) - Static method in class org.apache.avro.mapred.AvroOutputFormat
Set the sync interval to be used by the underlying DataFileWriter.
setTabSize(int) - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
setTemplateDir(String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
Set the resource directory where templates reside.
setTimeout(int) - Method in class org.apache.avro.ipc.HttpTransceiver
Set the connect and read timeouts, in milliseconds.
setTimeStamp(long) - Method in class org.apache.avro.ipc.trace.TimestampedEvent.Builder
Sets the value of the 'timeStamp' field
setTimeStamp(Long) - Method in class org.apache.avro.ipc.trace.TimestampedEvent
Sets the value of the 'timeStamp' field.
setTraceID(ID) - Method in class org.apache.avro.ipc.trace.Span.Builder
Sets the value of the 'traceID' field
setTraceID(ID) - Method in class org.apache.avro.ipc.trace.Span
Sets the value of the 'traceID' field.
setTypes(Collection<Schema>) - Method in class org.apache.avro.Protocol
Set the types of this protocol.
setValidate(boolean) - Method in class org.apache.avro.Schema.Parser
Enable or disable name validation.
setValue(Object) - Method in interface org.apache.avro.data.ErrorBuilder
Sets the value
setValue(V) - Method in class org.apache.avro.hadoop.io.AvroKeyValue
Sets the value.
setValue(Object) - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
 
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.
SINGLE_LINE_COMMENT - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
singleton - Static variable in class org.apache.avro.ipc.trace.TracePlugin
 
singletonConf - Static variable in class org.apache.avro.ipc.trace.TracePlugin
 
size() - Method in class org.apache.avro.generic.GenericData.Array
 
size() - Method in class org.apache.avro.io.parsing.Symbol.Alternative
 
size - Variable in class org.apache.avro.io.parsing.Symbol.IntCheckAction
 
size() - Method in class org.apache.avro.io.parsing.Symbol.Sequence
 
size(int) - Method in class org.apache.avro.SchemaBuilder.FixedBuilder
Configure this fixed type's size, and end its configuration.
size() - Method in class org.apache.avro.util.WeakIdentityHashMap
 
sizeEstimate() - Method in class org.apache.trevni.avro.AvroColumnWriter
Return the approximate size of the file that will be written.
sizeEstimate() - Method in class org.apache.trevni.ColumnFileWriter
Return the approximate size of the file that will be written.
skip(Schema, Decoder) - Static method in class org.apache.avro.generic.GenericDatumReader
Skip an instance of a schema.
skipAction() - Method in interface org.apache.avro.io.parsing.SkipParser.SkipHandler
Skips the action at the top of the stack.
skipAction(Symbol) - Static method in class org.apache.avro.io.parsing.Symbol
 
skipAction() - Method in class org.apache.avro.io.ParsingDecoder
 
skipAction() - Method in class org.apache.avro.io.ResolvingDecoder
 
skipArray() - Method in class org.apache.avro.io.BinaryDecoder
 
skipArray() - Method in class org.apache.avro.io.Decoder
Used for quickly skipping through an array.
skipArray() - Method in class org.apache.avro.io.JsonDecoder
 
skipArray() - Method in class org.apache.avro.io.ValidatingDecoder
 
skipBytes() - Method in class org.apache.avro.io.BinaryDecoder
 
skipBytes() - Method in class org.apache.avro.io.Decoder
Discards a byte-string written by Encoder.writeBytes(java.nio.ByteBuffer).
skipBytes() - Method in class org.apache.avro.io.JsonDecoder
 
skipBytes() - Method in class org.apache.avro.io.ValidatingDecoder
 
skipFixed(int) - Method in class org.apache.avro.io.BinaryDecoder
 
skipFixed(int) - Method in class org.apache.avro.io.Decoder
Discards fixed sized binary object.
skipFixed(int) - Method in class org.apache.avro.io.JsonDecoder
 
skipFixed() - Method in class org.apache.avro.io.JsonDecoder
 
skipFixed() - Method in class org.apache.avro.io.ParsingDecoder
 
skipFixed(int) - Method in class org.apache.avro.io.ValidatingDecoder
 
skipFixed() - Method in class org.apache.avro.io.ValidatingDecoder
 
skipLong(byte[], int) - Static method in class org.apache.avro.io.BinaryData
Skip a binary-encoded long, returning the position after it.
skipMap() - Method in class org.apache.avro.io.BinaryDecoder
 
skipMap() - Method in class org.apache.avro.io.Decoder
Support for quickly skipping through a map similar to Decoder.skipArray().
skipMap() - Method in class org.apache.avro.io.JsonDecoder
 
skipMap() - Method in class org.apache.avro.io.ValidatingDecoder
 
SkipParser - Class in org.apache.avro.io.parsing
A parser that capable of skipping as well read and write.
SkipParser(Symbol, Parser.ActionHandler, SkipParser.SkipHandler) - Constructor for class org.apache.avro.io.parsing.SkipParser
 
SkipParser.SkipHandler - Interface in org.apache.avro.io.parsing
The clients implement this interface to skip symbols and actions.
skipRepeater() - Method in class org.apache.avro.io.parsing.SkipParser
Skips the repeater at the top the stack.
skipString() - Method in class org.apache.avro.io.BinaryDecoder
 
skipString() - Method in class org.apache.avro.io.Decoder
Discards a char-string written by Encoder.writeString(org.apache.avro.util.Utf8).
skipString() - Method in class org.apache.avro.io.JsonDecoder
 
skipString() - Method in class org.apache.avro.io.ValidatingDecoder
 
skipSymbol(Symbol) - Method in class org.apache.avro.io.parsing.SkipParser
Pushes the given symbol on to the skip and skips it.
skipTo(int) - Method in class org.apache.avro.io.parsing.SkipParser
Skips data by calling skipXyz or readXyz methods on this, until the parser stack reaches the target level.
skipTopSymbol() - Method in interface org.apache.avro.io.parsing.SkipParser.SkipHandler
Skips the symbol at the top of the stack.
skipTopSymbol() - Method in class org.apache.avro.io.ParsingDecoder
 
SNAPPY_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
 
snappyCodec() - Static method in class org.apache.avro.file.CodecFactory
Snappy codec.
SocketServer - Class in org.apache.avro.ipc
Deprecated.
use SaslSocketServer instead.
SocketServer(Responder, SocketAddress) - Constructor for class org.apache.avro.ipc.SocketServer
Deprecated.
 
SocketTransceiver - Class in org.apache.avro.ipc
Deprecated.
SocketTransceiver(SocketAddress) - Constructor for class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
SocketTransceiver(SocketChannel) - Constructor for class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
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(SortedKeyValueFile.Reader.Options) - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
Constructs a reader.
SortedKeyValueFile.Reader.Options - Class in org.apache.avro.hadoop.file
A class to encapsulate the options of a Reader.
SortedKeyValueFile.Reader.Options() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
 
SortedKeyValueFile.Writer<K,V> - Class in org.apache.avro.hadoop.file
Writes a SortedKeyValueFile.
SortedKeyValueFile.Writer(SortedKeyValueFile.Writer.Options) - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
Creates a writer for a new file.
SortedKeyValueFile.Writer.Options - Class in org.apache.avro.hadoop.file
A class to encapsulate the various options of a SortedKeyValueFile.Writer.
SortedKeyValueFile.Writer.Options() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
 
Span - Class in org.apache.avro.ipc.trace
 
Span() - Constructor for class org.apache.avro.ipc.trace.Span
Default constructor.
Span(ID, ID, ID, String, Long, Long, String, String, List<TimestampedEvent>, Boolean) - Constructor for class org.apache.avro.ipc.trace.Span
All-args constructor.
span - Variable in class org.apache.avro.ipc.trace.TraceNode
The Span to which corresponds to this node in the call tree.
Span.Builder - Class in org.apache.avro.ipc.trace
RecordBuilder for Span instances.
SpanAggregator - Class in org.apache.avro.ipc.trace
Utility methods for aggregating spans together at various points of trace analysis.
SpanAggregator() - Constructor for class org.apache.avro.ipc.trace.SpanAggregator
 
SpanAggregator.SpanAggregationResults - Class in org.apache.avro.ipc.trace
Class to store the results of span aggregation.
SpanAggregator.SpanAggregationResults() - Constructor for class org.apache.avro.ipc.trace.SpanAggregator.SpanAggregationResults
 
SpanAggregator.TraceFormationResults - Class in org.apache.avro.ipc.trace
Class to store the results of trace formation.
SpanAggregator.TraceFormationResults() - Constructor for class org.apache.avro.ipc.trace.SpanAggregator.TraceFormationResults
 
SpanEvent - Enum in org.apache.avro.ipc.trace
 
spanID - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
spans - Variable in class org.apache.avro.ipc.trace.InMemorySpanStorage
 
SpanStorage - Interface in org.apache.avro.ipc.trace
Responsible for storing spans locally and answering span queries.
spanStorageDir - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
specialToken - Variable in class org.apache.avro.compiler.idl.Token
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
SpecificCompiler - Class in org.apache.avro.compiler.specific
Generate specific Java interfaces and classes for protocols and schemas.
SpecificCompiler(Protocol) - Constructor for class org.apache.avro.compiler.specific.SpecificCompiler
 
SpecificCompiler(Schema) - Constructor for class org.apache.avro.compiler.specific.SpecificCompiler
 
SpecificCompiler.FieldVisibility - Enum in org.apache.avro.compiler.specific
 
SpecificCompiler.Slf4jLogChute - Class in org.apache.avro.compiler.specific
 
SpecificCompiler.Slf4jLogChute() - Constructor for class org.apache.avro.compiler.specific.SpecificCompiler.Slf4jLogChute
 
SpecificCompilerTool - Class in org.apache.avro.tool
A Tool for compiling avro protocols or schemas to Java classes using the Avro SpecificCompiler.
SpecificCompilerTool() - Constructor for class org.apache.avro.tool.SpecificCompilerTool
 
SpecificData - Class in org.apache.avro.specific
Utilities for generated Java classes and interfaces.
SpecificData() - Constructor for class org.apache.avro.specific.SpecificData
For subclasses.
SpecificData(ClassLoader) - Constructor for class org.apache.avro.specific.SpecificData
Construct with a specific classloader.
SpecificData.SchemaConstructable - Interface in org.apache.avro.specific
Tag interface that indicates that a class has a one-argument constructor that accepts a Schema.
SpecificDatumReader<T> - Class in org.apache.avro.specific
DatumReader for generated Java classes.
SpecificDatumReader() - Constructor for class org.apache.avro.specific.SpecificDatumReader
 
SpecificDatumReader(Class<T>) - Constructor for class org.apache.avro.specific.SpecificDatumReader
Construct for reading instances of a class.
SpecificDatumReader(Schema) - Constructor for class org.apache.avro.specific.SpecificDatumReader
Construct where the writer's and reader's schemas are the same.
SpecificDatumReader(Schema, Schema) - Constructor for class org.apache.avro.specific.SpecificDatumReader
Construct given writer's and reader's schema.
SpecificDatumReader(Schema, Schema, SpecificData) - Constructor for class org.apache.avro.specific.SpecificDatumReader
Construct given writer's schema, reader's schema, and a SpecificData.
SpecificDatumReader(SpecificData) - Constructor for class org.apache.avro.specific.SpecificDatumReader
Construct given a SpecificData.
SpecificDatumWriter<T> - Class in org.apache.avro.specific
DatumWriter for generated Java classes.
SpecificDatumWriter() - Constructor for class org.apache.avro.specific.SpecificDatumWriter
 
SpecificDatumWriter(Class<T>) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
 
SpecificDatumWriter(Schema) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
 
SpecificDatumWriter(Schema, SpecificData) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
 
SpecificDatumWriter(SpecificData) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
 
SpecificErrorBuilderBase<T extends SpecificExceptionBase> - Class in org.apache.avro.specific
Abstract base class for specific ErrorBuilder implementations.
SpecificErrorBuilderBase(Schema) - Constructor for class org.apache.avro.specific.SpecificErrorBuilderBase
Creates a SpecificErrorBuilderBase for building errors of the given type.
SpecificErrorBuilderBase(SpecificErrorBuilderBase<T>) - Constructor for class org.apache.avro.specific.SpecificErrorBuilderBase
SpecificErrorBuilderBase copy constructor.
SpecificErrorBuilderBase(T) - Constructor for class org.apache.avro.specific.SpecificErrorBuilderBase
Creates a SpecificErrorBuilderBase by copying an existing error instance.
SpecificExceptionBase - Exception in org.apache.avro.specific
Base class for specific exceptions.
SpecificExceptionBase() - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
 
SpecificExceptionBase(Throwable) - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
 
SpecificExceptionBase(Object) - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
 
SpecificExceptionBase(Object, Throwable) - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
 
SpecificFixed - Class in org.apache.avro.specific
Base class for generated fixed-sized data classes.
SpecificFixed() - Constructor for class org.apache.avro.specific.SpecificFixed
 
SpecificFixed(byte[]) - Constructor for class org.apache.avro.specific.SpecificFixed
 
SpecificRecord - Interface in org.apache.avro.specific
Implemented by generated record classes.
SpecificRecordBase - Class in org.apache.avro.specific
Base class for generated record classes.
SpecificRecordBase() - Constructor for class org.apache.avro.specific.SpecificRecordBase
 
SpecificRecordBuilderBase<T extends SpecificRecord> - Class in org.apache.avro.specific
Abstract base class for specific RecordBuilder implementations.
SpecificRecordBuilderBase(Schema) - Constructor for class org.apache.avro.specific.SpecificRecordBuilderBase
Creates a SpecificRecordBuilderBase for building records of the given type.
SpecificRecordBuilderBase(SpecificRecordBuilderBase<T>) - Constructor for class org.apache.avro.specific.SpecificRecordBuilderBase
SpecificRecordBuilderBase copy constructor.
SpecificRecordBuilderBase(T) - Constructor for class org.apache.avro.specific.SpecificRecordBuilderBase
Creates a SpecificRecordBuilderBase by copying an existing record instance.
SpecificRequestor - Class in org.apache.avro.ipc.specific
Requestor for generated interfaces.
SpecificRequestor(Class<?>, Transceiver) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
 
SpecificRequestor(Protocol, Transceiver) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
 
SpecificRequestor(Class<?>, Transceiver, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
 
SpecificRequestor(Protocol, Transceiver, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
 
SpecificResponder - Class in org.apache.avro.ipc.specific
Responder for generated interfaces.
SpecificResponder(Class, Object) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
 
SpecificResponder(Protocol, Object) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
 
SpecificResponder(Class, Object, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
 
SpecificResponder(Protocol, Object, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
 
stack - Variable in class org.apache.avro.io.parsing.Parser
 
start() - Method in class org.apache.avro.ipc.HttpServer
Start the server.
start() - Method in class org.apache.avro.ipc.NettyServer
 
start() - Method in interface org.apache.avro.ipc.Server
Start this server.
startItem() - Method in class org.apache.avro.io.BinaryEncoder
 
startItem() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
startItem() - Method in class org.apache.avro.io.Encoder
Start a new item of an array or map.
startItem() - Method in class org.apache.avro.io.JsonEncoder
 
startItem() - Method in class org.apache.avro.io.ParsingEncoder
 
startItem() - Method in class org.apache.avro.io.ValidatingEncoder
 
startRow() - Method in class org.apache.trevni.ColumnFileWriter
Expert: Called before any values are written to a row.
startRow() - Method in class org.apache.trevni.ColumnValues
Expert: Must be called before any calls to ColumnValues.nextLength() or ColumnValues.nextValue().
startupTime - Variable in class org.apache.avro.ipc.stats.StatsPlugin
How long I've been alive
staticFlag - Static variable in class org.apache.avro.compiler.idl.JavaCharStream
Whether parser is static.
StaticServlet - Class in org.apache.avro.ipc.stats
Very simple servlet class capable of serving static files.
StaticServlet() - Constructor for class org.apache.avro.ipc.stats.StaticServlet
 
StaticServlet - Class in org.apache.avro.ipc.trace
Very simple servlet class capable of serving static files.
StaticServlet() - Constructor for class org.apache.avro.ipc.trace.StaticServlet
 
StatsPlugin - Class in org.apache.avro.ipc.stats
Collects count and latency statistics about RPC calls.
StatsPlugin() - Constructor for class org.apache.avro.ipc.stats.StatsPlugin
Construct a plugin with default (system) ticks, and default histogram segmentation.
StatsServer - Class in org.apache.avro.ipc.stats
 
StatsServer(StatsPlugin, int) - Constructor for class org.apache.avro.ipc.stats.StatsServer
 
StatsServlet - Class in org.apache.avro.ipc.stats
Exposes information provided by a StatsPlugin as a web page.
StatsServlet(StatsPlugin) - Constructor for class org.apache.avro.ipc.stats.StatsServlet
 
StatsServlet.RenderableMessage - Class in org.apache.avro.ipc.stats
 
StatsServlet.RenderableMessage(String) - Constructor for class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
 
status(String) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
Update the task's status message.
stop() - Method in class org.apache.avro.ipc.stats.StatsServer
 
stopClientServer() - Method in class org.apache.avro.ipc.trace.TracePlugin
 
storage - Variable in class org.apache.avro.ipc.trace.TracePlugin
 
storageType - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
STRING - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
STRING - Static variable in class org.apache.avro.io.parsing.Symbol
 
STRING_LITERAL - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
STRING_PROP - Static variable in class org.apache.avro.generic.GenericData
 
STRING_TYPE_STRING - Static variable in class org.apache.avro.generic.GenericData
 
Stringable - Annotation Type in org.apache.avro.reflect
Declares that a class or field should be represented by an Avro string.
stringableClasses - Variable in class org.apache.avro.specific.SpecificData
Read/write some common builtin classes as strings.
stringBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
Build a string type that can set custom properties.
stringBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build a string type that can set custom properties.
stringBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
Build a string type that can set custom properties.
stringDefault(String) - Method in class org.apache.avro.SchemaBuilder.StringDefault
Completes this field with the default value provided.
stringType - Variable in class org.apache.avro.mojo.AbstractAvroMojo
The Java type to use for Avro strings.
stringType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
A plain string type without custom properties.
stringType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
A plain string type without custom properties.
stringType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
A plain string type without custom properties.
STUFF_TO_IGNORE - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
submitJob(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
Submit a job to the Map-Reduce framework.
subSequence(int, int) - Method in class org.apache.avro.util.Utf8
 
SwitchTo(int) - Method in class org.apache.avro.compiler.idl.IdlTokenManager
Switch to specified lex state.
Symbol - Class in org.apache.avro.io.parsing
Symbol is the base of all symbols (terminals and non-terminals) of the grammar.
Symbol(Symbol.Kind) - Constructor for class org.apache.avro.io.parsing.Symbol
Constructs a new symbol of the given kind kind.
Symbol(Symbol.Kind, Symbol[]) - Constructor for class org.apache.avro.io.parsing.Symbol
 
Symbol.Alternative - Class in org.apache.avro.io.parsing
 
Symbol.DefaultStartAction - Class in org.apache.avro.io.parsing
 
Symbol.DefaultStartAction(byte[]) - Constructor for class org.apache.avro.io.parsing.Symbol.DefaultStartAction
Deprecated.
Symbol.EnumAdjustAction - Class in org.apache.avro.io.parsing
 
Symbol.EnumAdjustAction(int, Object[]) - Constructor for class org.apache.avro.io.parsing.Symbol.EnumAdjustAction
Deprecated.
Symbol.EnumLabelsAction - Class in org.apache.avro.io.parsing
 
Symbol.EnumLabelsAction(List<String>) - Constructor for class org.apache.avro.io.parsing.Symbol.EnumLabelsAction
Deprecated.
Symbol.ErrorAction - Class in org.apache.avro.io.parsing
 
Symbol.FieldAdjustAction - Class in org.apache.avro.io.parsing
 
Symbol.FieldAdjustAction(int, String) - Constructor for class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
Deprecated.
Symbol.FieldOrderAction - Class in org.apache.avro.io.parsing
 
Symbol.FieldOrderAction(Schema.Field[]) - Constructor for class org.apache.avro.io.parsing.Symbol.FieldOrderAction
Deprecated.
Symbol.ImplicitAction - Class in org.apache.avro.io.parsing
 
Symbol.IntCheckAction - Class in org.apache.avro.io.parsing
 
Symbol.IntCheckAction(int) - Constructor for class org.apache.avro.io.parsing.Symbol.IntCheckAction
Deprecated.
Symbol.Kind - Enum in org.apache.avro.io.parsing
 
Symbol.Repeater - Class in org.apache.avro.io.parsing
 
Symbol.ResolvingAction - Class in org.apache.avro.io.parsing
 
Symbol.Root - Class in org.apache.avro.io.parsing
 
Symbol.Sequence - Class in org.apache.avro.io.parsing
 
Symbol.SkipAction - Class in org.apache.avro.io.parsing
 
Symbol.SkipAction(Symbol) - Constructor for class org.apache.avro.io.parsing.Symbol.SkipAction
Deprecated.
Symbol.UnionAdjustAction - Class in org.apache.avro.io.parsing
 
Symbol.UnionAdjustAction(int, Symbol) - Constructor for class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
Deprecated.
Symbol.WriterUnionAction - Class in org.apache.avro.io.parsing
 
symbolHandler - Variable in class org.apache.avro.io.parsing.Parser
 
symbols - Variable in class org.apache.avro.io.parsing.Symbol.Alternative
 
symbols - Variable in class org.apache.avro.io.parsing.Symbol.EnumLabelsAction
 
symbols(String...) - Method in class org.apache.avro.SchemaBuilder.EnumBuilder
Configure this enum type's symbols, and end its configuration.
symToParse - Variable in class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
 
symToSkip - Variable in class org.apache.avro.io.parsing.Symbol.SkipAction
 
sync(long) - Method in class org.apache.avro.file.DataFileReader
Move to the next synchronization point after a position.
sync(long) - Method in class org.apache.avro.file.DataFileReader12
Move to the next synchronization point after a position.
sync() - Method in class org.apache.avro.file.DataFileWriter
Return the current position as a value that may be passed to DataFileReader.seek(long).
sync(long) - Method in interface org.apache.avro.file.FileReader
Move to the next synchronization point after a position.
sync() - Method in interface org.apache.avro.file.Syncable
Sync the file to disk.
sync() - Method in class org.apache.avro.file.SyncableFileOutputStream
Sync the file to disk.
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.
SYNC_SIZE - Static variable in class org.apache.avro.file.DataFileConstants
 
Syncable - Interface in org.apache.avro.file
 
Syncable - Interface in org.apache.avro.mapreduce
 
SyncableFileOutputStream - Class in org.apache.avro.file
An implementation of Syncable which writes to a file.
SyncableFileOutputStream(String) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
Creates an instance of SyncableFileOutputStream with the given name.
SyncableFileOutputStream(File) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
Creates an instance of SyncableFileOutputStream using the given File instance.
SyncableFileOutputStream(String, boolean) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
Creates an instance of SyncableFileOutputStream with the given name and optionally append to the file if it already exists.
SyncableFileOutputStream(File, boolean) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
Creates an instance of SyncableFileOutputStream that writes to the file represented by the given File instance and optionally append to the file if it already exists.
SyncableFileOutputStream(FileDescriptor) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
Creates an instance of SyncableFileOutputStream using the given FileDescriptor instance.
SYSTEM_ERROR - Static variable in class org.apache.avro.Protocol
An error that can be thrown by any message.
SYSTEM_ERRORS - Static variable in class org.apache.avro.Protocol
Union type for generating system errors.

T

tabSize - Variable in class org.apache.avro.compiler.idl.JavaCharStream
 
TaskType - Enum in org.apache.avro.mapred.tether
 
tell() - Method in class org.apache.avro.file.DataFileReader
 
tell() - Method in class org.apache.avro.file.DataFileReader12
Return the current position in the input.
tell() - Method in interface org.apache.avro.file.FileReader
Return the current position in the input.
tell() - Method in class org.apache.avro.file.SeekableByteArrayInput
 
tell() - Method in class org.apache.avro.file.SeekableFileInput
 
tell() - Method in interface org.apache.avro.file.SeekableInput
Return the position of the next read().
tell() - Method in class org.apache.avro.mapred.FsInput
 
tell() - Method in class org.apache.avro.mapred.SequenceFileReader
 
templateDirectory - Variable in class org.apache.avro.mojo.AbstractAvroMojo
The directory (within the java classpath) that contains the velocity templates to use for code generation.
testExcludes - Variable in class org.apache.avro.mojo.AbstractAvroMojo
A set of Ant-like exclusion patterns used to prevent certain files from being processed.
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
 
TetherJob - Class in org.apache.avro.mapred.tether
Constructs and submits tether jobs.
TetherJob() - Constructor for class org.apache.avro.mapred.tether.TetherJob
 
TetherTool - Class in org.apache.avro.tool
 
TetherTool() - Constructor for class org.apache.avro.tool.TetherTool
 
TEXT_PREFIX - Static variable in class org.apache.avro.mapred.AvroJob
The configuration key prefix for a text output metadata.
ThriftData - Class in org.apache.avro.thrift
Utilities for serializing Thrift data in Avro format.
ThriftData() - Constructor for class org.apache.avro.thrift.ThriftData
 
ThriftDatumReader<T> - Class in org.apache.avro.thrift
DatumReader for generated Thrift classes.
ThriftDatumReader() - Constructor for class org.apache.avro.thrift.ThriftDatumReader
 
ThriftDatumReader(Class<T>) - Constructor for class org.apache.avro.thrift.ThriftDatumReader
 
ThriftDatumReader(Schema) - Constructor for class org.apache.avro.thrift.ThriftDatumReader
Construct where the writer's and reader's schemas are the same.
ThriftDatumReader(Schema, Schema) - Constructor for class org.apache.avro.thrift.ThriftDatumReader
Construct given writer's and reader's schema.
ThriftDatumReader(Schema, Schema, ThriftData) - Constructor for class org.apache.avro.thrift.ThriftDatumReader
 
ThriftDatumWriter<T> - Class in org.apache.avro.thrift
DatumWriter for generated thrift classes.
ThriftDatumWriter() - Constructor for class org.apache.avro.thrift.ThriftDatumWriter
 
ThriftDatumWriter(Class<T>) - Constructor for class org.apache.avro.thrift.ThriftDatumWriter
 
ThriftDatumWriter(Schema) - Constructor for class org.apache.avro.thrift.ThriftDatumWriter
 
ThriftDatumWriter(Schema, ThriftData) - Constructor for class org.apache.avro.thrift.ThriftDatumWriter
 
ThriftDatumWriter(ThriftData) - Constructor for class org.apache.avro.thrift.ThriftDatumWriter
 
THROWS - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
TICK - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
timeStamp - Variable in class org.apache.avro.ipc.trace.TimestampedEvent
Deprecated.
TimestampedEvent - Class in org.apache.avro.ipc.trace
 
TimestampedEvent() - Constructor for class org.apache.avro.ipc.trace.TimestampedEvent
Default constructor.
TimestampedEvent(Long, Object) - Constructor for class org.apache.avro.ipc.trace.TimestampedEvent
All-args constructor.
TimestampedEvent.Builder - Class in org.apache.avro.ipc.trace
RecordBuilder for TimestampedEvent instances.
toJson(Input, PrintStream, boolean) - Method in class org.apache.avro.tool.TrevniToJsonTool
Read a Trevni file and print each row as a JSON object.
token - Variable in class org.apache.avro.compiler.idl.Idl
Current token.
Token - Class in org.apache.avro.compiler.idl
Describes the input token stream.
Token() - Constructor for class org.apache.avro.compiler.idl.Token
No-argument constructor
Token(int) - Constructor for class org.apache.avro.compiler.idl.Token
Constructs a new token for the specified Image.
Token(int, String) - Constructor for class org.apache.avro.compiler.idl.Token
Constructs a new token for the specified Image and Kind.
token_source - Variable in class org.apache.avro.compiler.idl.Idl
Generated Token Manager.
tokenImage - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
Literal token values.
tokenImage - Variable in exception org.apache.avro.compiler.idl.ParseException
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
TokenMgrError - Error in org.apache.avro.compiler.idl
Token Manager Error.
TokenMgrError() - Constructor for error org.apache.avro.compiler.idl.TokenMgrError
No arg constructor.
TokenMgrError(String, int) - Constructor for error org.apache.avro.compiler.idl.TokenMgrError
Constructor with message and reason.
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.avro.compiler.idl.TokenMgrError
Full Constructor.
Tool - Interface in org.apache.avro.tool
Command-line "avro-tools" utilities should implement this interface for delegation by Main.
toParsingForm(Schema) - Static method in class org.apache.avro.SchemaNormalization
Returns "Parsing Canonical Form" of a schema as defined by Avro spec.
topSymbol() - Method in class org.apache.avro.io.parsing.Parser
Returns the top symbol from the stack.
toString() - Method in class org.apache.avro.compiler.idl.Token
Returns the image.
toString() - Method in class org.apache.avro.file.Codec
 
toString() - Method in class org.apache.avro.file.CodecFactory
 
toString() - Method in class org.apache.avro.file.XZCodec
 
toString() - Method in class org.apache.avro.generic.GenericData.Array
 
toString() - Method in class org.apache.avro.generic.GenericData.EnumSymbol
 
toString() - Method in class org.apache.avro.generic.GenericData.Fixed
 
toString() - Method in class org.apache.avro.generic.GenericData.Record
 
toString(Object) - Method in class org.apache.avro.generic.GenericData
Renders a Java datum as JSON.
toString(Object, StringBuilder) - Method in class org.apache.avro.generic.GenericData
Renders a Java datum as JSON.
toString() - Method in interface org.apache.avro.generic.GenericEnumSymbol
Return the symbol.
toString() - Method in class org.apache.avro.mapred.AvroWrapper
Get the wrapped datum as JSON.
toString() - Method in class org.apache.avro.mapred.Pair
 
toString() - Method in class org.apache.avro.Protocol.Message
 
toString() - Method in class org.apache.avro.Protocol
Render this as JSON.
toString(boolean) - Method in class org.apache.avro.Protocol
Render this as JSON.
toString() - Method in class org.apache.avro.Schema.Field
 
toString() - Method in class org.apache.avro.Schema
Render this as JSON.
toString(boolean) - Method in class org.apache.avro.Schema
Render this as JSON.
toString() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
toString() - Method in class org.apache.avro.specific.SpecificRecordBase
 
toString() - Method in class org.apache.avro.util.Utf8
 
toString() - Method in class org.apache.trevni.MetaData
 
ToTextTool - Class in org.apache.avro.tool
Reads an avro data file into a plain text file.
ToTextTool() - Constructor for class org.apache.avro.tool.ToTextTool
 
ToTrevniTool - Class in org.apache.avro.tool
Reads an Avro data file and writes a Trevni file.
ToTrevniTool() - Constructor for class org.apache.avro.tool.ToTrevniTool
 
Trace - Class in org.apache.avro.ipc.trace
A Trace is a tree of spans which reflects the actual call structure of a recursive RPC call tree.
Trace(TraceNode) - Constructor for class org.apache.avro.ipc.trace.Trace
Construct a trace given a root TraceNode.
TraceClientServlet - Class in org.apache.avro.ipc.trace
 
TraceClientServlet() - Constructor for class org.apache.avro.ipc.trace.TraceClientServlet
 
TraceCollection - Class in org.apache.avro.ipc.trace
Provides statistics and representation of a collection of Trace's which share the same execution path.
TraceCollection(Trace) - Constructor for class org.apache.avro.ipc.trace.TraceCollection
Create a TraceCollection using the given Trace as a model.
TraceCollection.TraceComparotor - Class in org.apache.avro.ipc.trace
 
TraceCollection.TraceComparotor() - Constructor for class org.apache.avro.ipc.trace.TraceCollection.TraceComparotor
 
TraceCollection.TraceNodeStats - Class in org.apache.avro.ipc.trace
Class to store statistics for a particular node in the RPC call tree.
TraceCollection.TraceNodeStats(TraceNode) - Constructor for class org.apache.avro.ipc.trace.TraceCollection.TraceNodeStats
Create a TraceNodeStats given a root TraceNode.
TraceCollection.TraceTiming - Class in org.apache.avro.ipc.trace
Class to store the timing data associated with a particluar trace.
TraceCollection.TraceTiming(Long, Long, Long) - Constructor for class org.apache.avro.ipc.trace.TraceCollection.TraceTiming
 
traceID - Variable in class org.apache.avro.ipc.trace.Span
Deprecated.
TraceNode - Class in org.apache.avro.ipc.trace
A node of of an RPC Trace.
TraceNode(Span, List<TraceNode>) - Constructor for class org.apache.avro.ipc.trace.TraceNode
 
TracePlugin - Class in org.apache.avro.ipc.trace
A tracing plugin for Avro.
TracePlugin(TracePluginConfiguration) - Constructor for class org.apache.avro.ipc.trace.TracePlugin
 
TracePlugin.StorageType - Enum in org.apache.avro.ipc.trace
 
TracePluginConfiguration - Class in org.apache.avro.ipc.trace
Helper class for configuring Avro's TracePlugin.
TracePluginConfiguration() - Constructor for class org.apache.avro.ipc.trace.TracePluginConfiguration
Return a TracePluginConfiguration with default options.
traceProb - Variable in class org.apache.avro.ipc.trace.TracePluginConfiguration
 
traces - Variable in class org.apache.avro.ipc.trace.SpanAggregator.TraceFormationResults
Traces which were successfully created.
transceive(List<ByteBuffer>) - Method in class org.apache.avro.ipc.LocalTransceiver
 
transceive(List<ByteBuffer>) - Method in class org.apache.avro.ipc.NettyTransceiver
Override as non-synchronized method because the method is thread safe.
transceive(List<ByteBuffer>, Callback<List<ByteBuffer>>) - Method in class org.apache.avro.ipc.NettyTransceiver
 
transceive(List<ByteBuffer>) - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
transceive(List<ByteBuffer>) - Method in class org.apache.avro.ipc.Transceiver
Called by Requestor.request(String,Object) for two-way messages.
transceive(List<ByteBuffer>, Callback<List<ByteBuffer>>) - Method in class org.apache.avro.ipc.Transceiver
Called by Requestor.request(String,Object,Callback) for two-way messages using callbacks.
Transceiver - Class in org.apache.avro.ipc
Base transport class used by Requestor.
Transceiver() - Constructor for class org.apache.avro.ipc.Transceiver
 
TrevniCreateRandomTool - Class in org.apache.avro.tool
Tool to create randomly populated Trevni file based on an Avro schema
TrevniCreateRandomTool() - Constructor for class org.apache.avro.tool.TrevniCreateRandomTool
 
TrevniMetadataTool - Class in org.apache.avro.tool
Tool to print Trevni file metadata as JSON.
TrevniMetadataTool() - Constructor for class org.apache.avro.tool.TrevniMetadataTool
 
TrevniRuntimeException - Exception in org.apache.trevni
Base runtime exception thrown by Trevni.
TrevniRuntimeException(Throwable) - Constructor for exception org.apache.trevni.TrevniRuntimeException
 
TrevniRuntimeException(String) - Constructor for exception org.apache.trevni.TrevniRuntimeException
 
TrevniRuntimeException(String, Throwable) - Constructor for exception org.apache.trevni.TrevniRuntimeException
 
TrevniToJsonTool - Class in org.apache.avro.tool
Tool to read Trevni files and print them as JSON.
TrevniToJsonTool() - Constructor for class org.apache.avro.tool.TrevniToJsonTool
 
TRUE - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
Type() - Method in class org.apache.avro.compiler.idl.Idl
 
type(Schema) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Use the schema provided as the type.
type(String) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Look up the type by name.
type(String, String) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Look up the type by name and namespace.
type() - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
Final step in configuring this field, finalizing name, namespace, alias, and order.
type(Schema) - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
Final step in configuring this field, finalizing name, namespace, alias, and order.
type(String) - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
Final step in configuring this field, finalizing name, namespace, alias, and order.
type(String, String) - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
Final step in configuring this field, finalizing name, namespace, alias, and order.

U

UNION - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.
UNION - Static variable in class org.apache.avro.io.parsing.Symbol
 
Union - Annotation Type in org.apache.avro.reflect
Declares that a Java type should be represented by an Avro union schema.
UNION_END - Static variable in class org.apache.avro.io.parsing.Symbol
 
unionAdjustAction(int, Symbol) - Static method in class org.apache.avro.io.parsing.Symbol
 
UnionDefinition() - Method in class org.apache.avro.compiler.idl.Idl
 
unionOf() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
Build an Avro union schema type.
unionOf() - Method in class org.apache.avro.SchemaBuilder.FieldTypeBuilder
Build an Avro union schema type.
unionOf() - Method in class org.apache.avro.SchemaBuilder.TypeBuilder
 
unionOf() - Static method in class org.apache.avro.SchemaBuilder
Create a builder for an Avro union This is equivalent to:
unlockChannel() - Method in class org.apache.avro.ipc.NettyTransceiver
Netty channels are thread-safe, so there is no need to acquire locks.
unlockChannel() - Method in class org.apache.avro.ipc.Transceiver
Releases the lock on the transceiver's channel if held by the calling thread.
UnresolvedUnionException - Exception in org.apache.avro
Thrown when the expected contents of a union cannot be resolved.
UnresolvedUnionException(Schema, Object) - Constructor for exception org.apache.avro.UnresolvedUnionException
 
UpdateLineColumn(char) - Method in class org.apache.avro.compiler.idl.JavaCharStream
 
Utf8 - Class in org.apache.avro.util
A Utf8 string.
Utf8() - Constructor for class org.apache.avro.util.Utf8
 
Utf8(String) - Constructor for class org.apache.avro.util.Utf8
 
Utf8(Utf8) - Constructor for class org.apache.avro.util.Utf8
 
Utf8(byte[]) - Constructor for class org.apache.avro.util.Utf8
 
UTF8 - Static variable in class org.apache.trevni.MetaData
 

V

validate(Schema.Field, Object) - Method in class org.apache.avro.data.RecordBuilderBase
Validates that a particular value for a given field is valid according to the following algorithm: 1.
validate(Schema, Object) - Method in class org.apache.avro.generic.GenericData
Returns true if a Java datum matches a schema.
validate(Schema, Object) - Method in class org.apache.avro.reflect.ReflectData
 
validatingDecoder(Schema, Decoder) - Method in class org.apache.avro.io.DecoderFactory
Creates a ValidatingDecoder wrapping the Decoder provided.
ValidatingDecoder - Class in org.apache.avro.io
An implementation of Decoder that ensures that the sequence of operations conforms to a schema.
validatingEncoder(Schema, Encoder) - Method in class org.apache.avro.io.EncoderFactory
Creates a ValidatingEncoder that wraps the Encoder provided.
ValidatingEncoder - Class in org.apache.avro.io
An implementation of Encoder that wraps another Encoder and ensures that the sequence of operations conforms to the provided schema.
ValidatingGrammarGenerator - Class in org.apache.avro.io.parsing
The class that generates validating grammar.
ValidatingGrammarGenerator() - Constructor for class org.apache.avro.io.parsing.ValidatingGrammarGenerator
 
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.compiler.specific.SpecificCompiler.FieldVisibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.generic.GenericData.StringType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.io.parsing.Symbol.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.ipc.HandshakeMatch
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.ipc.trace.SpanEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.ipc.trace.TracePlugin.StorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.mapred.tether.TaskType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.Schema.Field.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.Schema.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.avro.SchemaCompatibility.SchemaCompatibilityType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.trevni.ValueType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.avro.compiler.specific.SpecificCompiler.FieldVisibility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.avro.generic.GenericData.StringType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.avro.io.parsing.Symbol.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.avro.ipc.HandshakeMatch
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.avro.ipc.trace.SpanEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.avro.ipc.trace.TracePlugin.StorageType
Returns an array containing the constants of this enum type, in the order they are declared.
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.
values() - Static method in enum org.apache.avro.Schema.Field.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.avro.Schema.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.avro.SchemaBuilder.MapBuilder
Return a type builder for configuring the map's nested values schema.
values(Schema) - Method in class org.apache.avro.SchemaBuilder.MapBuilder
Complete configuration of this map, setting the schema of the map values to the schema provided.
values() - Static method in enum org.apache.avro.SchemaCompatibility.SchemaCompatibilityType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.avro.util.WeakIdentityHashMap
 
values() - Static method in enum org.apache.trevni.ValueType
Returns an array containing the constants of this enum type, in the order they are declared.
ValueType - Enum in org.apache.trevni
The datatypes that may be stored in a column.
VariableDeclarator(Schema, List<Schema.Field>) - Method in class org.apache.avro.compiler.idl.Idl
 
VERSION - Static variable in class org.apache.avro.file.DataFileConstants
 
VERSION - Static variable in class org.apache.avro.Protocol
The version of the protocol specification implemented here.
VOID - Static variable in interface org.apache.avro.compiler.idl.IdlConstants
RegularExpression Id.

W

WeakIdentityHashMap<K,V> - Class in org.apache.avro.util
Implements a combination of WeakHashMap and IdentityHashMap.
WeakIdentityHashMap() - Constructor for class org.apache.avro.util.WeakIdentityHashMap
 
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.
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.
withDefault(Object) - Method in class org.apache.avro.SchemaBuilder.GenericDefault
Completes this field with the default value provided.
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(JsonNode, Encoder) - Static method in class org.apache.avro.data.Json
Write Json data as Avro data.
write(JsonNode, Encoder) - Method in class org.apache.avro.data.Json.Writer
 
write(D, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
 
write(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write data.
write(D, Encoder) - Method in interface org.apache.avro.io.DatumWriter
Write a datum.
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.
write(Object, Encoder) - Method in class org.apache.avro.reflect.CustomEncoding
 
write(Object, Encoder) - Method in class org.apache.avro.reflect.DateAsLongEncoding
 
write(Schema, Object, Encoder) - Method in class org.apache.avro.reflect.ReflectDatumWriter
 
write(ByteBuffer) - Method in class org.apache.avro.util.ByteBufferOutputStream
 
write(int) - Method in class org.apache.avro.util.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class org.apache.avro.util.ByteBufferOutputStream
 
write(D) - Method in class org.apache.trevni.avro.AvroColumnWriter
Add a row to the file.
write(AvroKey<T>, NullWritable) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordWriter
write(AvroKey<K>, AvroValue<V>) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordWriter
writeArray(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a array.
writeArray(Schema, Object, Encoder) - Method in class org.apache.avro.reflect.ReflectDatumWriter
Called to write a array.
writeArrayEnd() - Method in class org.apache.avro.io.BinaryEncoder
 
writeArrayEnd() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeArrayEnd() - Method in class org.apache.avro.io.Encoder
Call this method to finish writing an array.
writeArrayEnd() - Method in class org.apache.avro.io.JsonEncoder
 
writeArrayEnd() - Method in class org.apache.avro.io.ValidatingEncoder
 
writeArrayStart() - Method in class org.apache.avro.io.BinaryEncoder
 
writeArrayStart() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeArrayStart() - Method in class org.apache.avro.io.Encoder
Call this method to start writing an array.
writeArrayStart() - Method in class org.apache.avro.io.JsonEncoder
 
writeArrayStart() - Method in class org.apache.avro.io.ValidatingEncoder
 
writeBoolean(boolean) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeBoolean(boolean) - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeBoolean(boolean) - Method in class org.apache.avro.io.DirectBinaryEncoder
 
writeBoolean(boolean) - Method in class org.apache.avro.io.Encoder
Write a boolean value.
writeBoolean(boolean) - Method in class org.apache.avro.io.JsonEncoder
 
writeBoolean(boolean) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeBuffer(ByteBuffer) - Method in class org.apache.avro.util.ByteBufferOutputStream
Add a buffer to the output without copying, if possible.
writeBuffers(List<ByteBuffer>) - Method in class org.apache.avro.ipc.DatagramTransceiver
 
writeBuffers(List<ByteBuffer>) - Method in class org.apache.avro.ipc.HttpTransceiver
 
writeBuffers(List<ByteBuffer>) - Method in class org.apache.avro.ipc.LocalTransceiver
 
writeBuffers(List<ByteBuffer>) - Method in class org.apache.avro.ipc.NettyTransceiver
 
writeBuffers(List<ByteBuffer>) - Method in class org.apache.avro.ipc.SaslSocketTransceiver
 
writeBuffers(List<ByteBuffer>) - Method in class org.apache.avro.ipc.SocketTransceiver
Deprecated.
 
writeBuffers(List<ByteBuffer>) - Method in class org.apache.avro.ipc.Transceiver
Called by Requestor.request(String,Object) for one-way messages.
writeBytes(Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a bytes.
writeBytes(ByteBuffer) - Method in class org.apache.avro.io.BinaryEncoder
 
writeBytes(byte[], int, int) - Method in class org.apache.avro.io.BinaryEncoder
 
writeBytes(ByteBuffer) - Method in class org.apache.avro.io.Encoder
Write a byte string.
writeBytes(byte[], int, int) - Method in class org.apache.avro.io.Encoder
Write a byte string.
writeBytes(byte[]) - Method in class org.apache.avro.io.Encoder
Writes a byte string.
writeBytes(ByteBuffer) - Method in class org.apache.avro.io.JsonEncoder
 
writeBytes(byte[], int, int) - Method in class org.apache.avro.io.JsonEncoder
 
writeBytes(ByteBuffer) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeBytes(byte[], int, int) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeBytes(Object, Encoder) - Method in class org.apache.avro.protobuf.ProtobufDatumWriter
 
writeBytes(Object, Encoder) - Method in class org.apache.avro.reflect.ReflectDatumWriter
 
writeBytes(Object, Encoder) - Method in class org.apache.avro.thrift.ThriftDatumWriter
 
writeDouble(double) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeDouble(double) - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeDouble(double) - Method in class org.apache.avro.io.DirectBinaryEncoder
 
writeDouble(double) - Method in class org.apache.avro.io.Encoder
Write a double.
writeDouble(double) - Method in class org.apache.avro.io.JsonEncoder
 
writeDouble(double) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeEnum(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write an enum value.
writeEnum(int) - Method in class org.apache.avro.io.BinaryEncoder
 
writeEnum(int) - Method in class org.apache.avro.io.Encoder
Writes an enumeration.
writeEnum(int) - Method in class org.apache.avro.io.JsonEncoder
 
writeEnum(int) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeEnum(Schema, Object, Encoder) - Method in class org.apache.avro.protobuf.ProtobufDatumWriter
 
writeEnum(Schema, Object, Encoder) - Method in class org.apache.avro.specific.SpecificDatumWriter
 
writeError(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.generic.GenericResponder
 
writeError(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.reflect.ReflectResponder
 
writeError(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.Responder
Writes an error message.
writeError(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.specific.SpecificResponder
 
writeField(Object, Schema.Field, Encoder, Object) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a single field of a record.
writeField(Object, Schema.Field, Encoder, Object) - Method in class org.apache.avro.reflect.ReflectDatumWriter
 
writeFixed(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a fixed value.
writeFixed(byte[], int, int) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeFixed(byte[], int, int) - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeFixed(ByteBuffer) - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeFixed(byte[], int, int) - Method in class org.apache.avro.io.DirectBinaryEncoder
 
writeFixed(byte[], int, int) - Method in class org.apache.avro.io.Encoder
Writes a fixed size binary object.
writeFixed(byte[]) - Method in class org.apache.avro.io.Encoder
A shorthand for writeFixed(bytes, 0, bytes.length)
writeFixed(ByteBuffer) - Method in class org.apache.avro.io.Encoder
Writes a fixed from a ByteBuffer.
writeFixed(byte[], int, int) - Method in class org.apache.avro.io.JsonEncoder
 
writeFixed(byte[], int, int) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeFloat(float) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeFloat(float) - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeFloat(float) - Method in class org.apache.avro.io.DirectBinaryEncoder
 
writeFloat(float) - Method in class org.apache.avro.io.Encoder
Write a float.
writeFloat(float) - Method in class org.apache.avro.io.JsonEncoder
 
writeFloat(float) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeIndex(int) - Method in class org.apache.avro.io.BinaryEncoder
 
writeIndex(int) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeIndex(int) - Method in class org.apache.avro.io.Encoder
Call this method to write the tag of a union.
writeIndex(int) - Method in class org.apache.avro.io.JsonEncoder
 
writeIndex(int) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeInt(int) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeInt(int) - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeInt(int) - Method in class org.apache.avro.io.DirectBinaryEncoder
 
writeInt(int) - Method in class org.apache.avro.io.Encoder
Writes a 32-bit integer.
writeInt(int) - Method in class org.apache.avro.io.JsonEncoder
 
writeInt(int) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeLength(int, int) - Method in class org.apache.trevni.ColumnFileWriter
Expert: Declare a count of items to be written to an array column or a column whose parent is an array.
writeLong(long) - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeLong(long) - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeLong(long) - Method in class org.apache.avro.io.DirectBinaryEncoder
 
writeLong(long) - Method in class org.apache.avro.io.Encoder
Write a 64-bit integer.
writeLong(long) - Method in class org.apache.avro.io.JsonEncoder
 
writeLong(long) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeMap(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a map.
writeMapEnd() - Method in class org.apache.avro.io.BinaryEncoder
 
writeMapEnd() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeMapEnd() - Method in class org.apache.avro.io.Encoder
Call this method to terminate the inner-most, currently-opened map.
writeMapEnd() - Method in class org.apache.avro.io.JsonEncoder
 
writeMapEnd() - Method in class org.apache.avro.io.ValidatingEncoder
 
writeMapStart() - Method in class org.apache.avro.io.BinaryEncoder
 
writeMapStart() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeMapStart() - Method in class org.apache.avro.io.Encoder
Call this to start a new map.
writeMapStart() - Method in class org.apache.avro.io.JsonEncoder
 
writeMapStart() - Method in class org.apache.avro.io.ValidatingEncoder
 
writeNull() - Method in class org.apache.avro.io.BinaryEncoder
 
writeNull() - Method in class org.apache.avro.io.Encoder
"Writes" a null value.
writeNull() - Method in class org.apache.avro.io.JsonEncoder
 
writeNull() - Method in class org.apache.avro.io.ValidatingEncoder
 
writer - Variable in class org.apache.avro.io.parsing.Symbol.ResolvingAction
 
writer - Variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
Trevni file writer
writeRecord(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a record.
writeRequest(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.generic.GenericRequestor
 
writeRequest(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.Requestor
Writes a request message.
writeRequest(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
 
writeResponse(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.generic.GenericResponder
 
writeResponse(Schema, Object, Encoder) - Method in class org.apache.avro.ipc.Responder
Writes a response message.
writeRow(Object...) - Method in class org.apache.trevni.ColumnFileWriter
Add a row to the file.
writerUnionAction() - Static method in class org.apache.avro.io.parsing.Symbol
 
writeString(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a string.
writeString(Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
Called to write a string.
writeString(Utf8) - Method in class org.apache.avro.io.BinaryEncoder
 
writeString(String) - Method in class org.apache.avro.io.BinaryEncoder
 
writeString(Utf8) - Method in class org.apache.avro.io.Encoder
Write a Unicode character string.
writeString(String) - Method in class org.apache.avro.io.Encoder
Write a Unicode character string.
writeString(CharSequence) - Method in class org.apache.avro.io.Encoder
Write a Unicode character string.
writeString(Utf8) - Method in class org.apache.avro.io.JsonEncoder
 
writeString(String) - Method in class org.apache.avro.io.JsonEncoder
 
writeString(Utf8) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeString(String) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeString(CharSequence) - Method in class org.apache.avro.io.ValidatingEncoder
 
writeString(Schema, Object, Encoder) - Method in class org.apache.avro.specific.SpecificDatumWriter
 
writeTo(OutputStream) - Method in class org.apache.trevni.avro.AvroColumnWriter
Write all rows added to the named output stream.
writeTo(File) - Method in class org.apache.trevni.avro.AvroColumnWriter
Write all rows added to the named file.
writeTo(File) - Method in class org.apache.trevni.ColumnFileWriter
Write all rows added to the named file.
writeTo(OutputStream) - Method in class org.apache.trevni.ColumnFileWriter
Write all rows added to the named output stream.
writeValue(Object, int) - Method in class org.apache.trevni.ColumnFileWriter
Expert: Add a value to a row.
writeZero() - Method in class org.apache.avro.io.BinaryEncoder
Write a zero byte to the underlying output.
writeZero() - Method in class org.apache.avro.io.BlockingBinaryEncoder
 
writeZero() - Method in class org.apache.avro.io.BufferedBinaryEncoder
 
writeZero() - Method in class org.apache.avro.io.DirectBinaryEncoder
 

X

XZ_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
 
XZ_LEVEL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
The configuration key for Avro XZ level.
xzCodec(int) - Static method in class org.apache.avro.file.CodecFactory
XZ codec, with specific compression.
XZCodec - Class in org.apache.avro.file
Implements xz compression and decompression.
XZCodec(int) - Constructor for class org.apache.avro.file.XZCodec
 
A B C D E F G H I J K L M N O P R S T U V W X 

Copyright © 2009-2014 The Apache Software Foundation. All Rights Reserved.