Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort() - Method in interface org.apache.avro.mapred.tether.InputProtocol
-
Called to abort the task.
- AbstractArray(Schema) - Constructor for class org.apache.avro.generic.GenericData.AbstractArray
- 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
- ACCESSOR_MUTATOR_RESERVED_WORDS - Static variable in class org.apache.avro.specific.SpecificData
- Action(Schema, Schema, GenericData, Resolver.Action.Type) - Constructor for class org.apache.avro.Resolver.Action
- actions - Variable in class org.apache.avro.Resolver.WriterUnion
- actualAction - Variable in class org.apache.avro.Resolver.ReaderUnion
- add(boolean) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- add(int, boolean) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- add(int, double) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- add(int, float) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- add(int, int) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- add(int, long) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- add(int, Boolean) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- add(int, Double) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- add(int, Float) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- add(int, Integer) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- add(int, Long) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- add(int, T) - Method in class org.apache.avro.generic.GenericData.Array
- add(Boolean) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- addAlias(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
- addAlias(String, String) - Method in class org.apache.avro.Schema
-
If this is a record, enum or fixed, add an alias.
- addAllProps(JsonProperties) - Method in class org.apache.avro.JsonProperties
-
Adds all the props from the specified json properties.
- addAvroTypeMsg(AvroTypeException, String) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Helper method for adding a message to an Avro Type Exception .
- addClassCastMsg(ClassCastException, String) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Helper method for adding a message to an Class Cast Exception .
- 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.jetty.HttpServer
- addCustomConversion(Class<?>) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- addFileset(FileSet) - Method in class org.apache.avro.compiler.specific.ProtocolTask
-
Add a fileset.
- addInputPath(JobConf, Path, Class<? extends AvroMapper>, Schema) - Static method in class org.apache.avro.mapred.AvroMultipleInputs
- addLogicalTypeConversion(Conversion<?>) - Method in class org.apache.avro.generic.GenericData
-
Registers the given conversion to be used when reading and writing with this data model.
- 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.
- addParentField(Schema.Field) - Method in exception class org.apache.avro.AvroMissingFieldException
- addProp(String, Object) - Method in class org.apache.avro.JsonProperties
- addProp(String, Object) - Method in class org.apache.avro.Schema
- addProp(String, String) - Method in class org.apache.avro.JsonProperties
-
Adds a property with the given name name and value value.
- addProp(String, String) - 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.
- addSchema(Schema) - Method in class org.apache.avro.message.BinaryMessageDecoder
-
Adds a
Schema
that can be used to decode buffers. - addSchema(Schema) - Method in class org.apache.avro.message.SchemaStore.Cache
-
Adds a schema to this cache that can be retrieved using its AVRO-CRC-64 fingerprint.
- addStringable(Class) - Method in class org.apache.avro.reflect.ReflectData
-
Cause a class to be treated as though it had an
Stringable
* annotation. - addTo(Temporal) - Method in class org.apache.avro.util.TimePeriod
- addToArray(Object, long, 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 add a value. - 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
-
Called by the default implementation of
GenericDatumReader.readMap(java.lang.Object, org.apache.avro.Schema, org.apache.avro.io.ResolvingDecoder)
to add a key/value pair. - addToSchema(Schema) - Method in class org.apache.avro.LogicalType
-
Add this logical type to the given Schema.
- addToSchema(Schema) - Method in class org.apache.avro.LogicalTypes.Decimal
- addTypes(Iterable<Schema>) - Method in class org.apache.avro.Schema.Parser
-
Adds the provided types to the set of defined, named types known to this parser.
- addTypes(Map<String, Schema>) - Method in class org.apache.avro.Schema.Parser
-
Deprecated.use addTypes(Iterable
types) - adjustAndSetValue(String, String) - Method in class org.apache.avro.Conversion
-
Certain logical types may require adjusting the code within the "setter" methods to make sure the data that is set is properly formatted.
- adjustAndSetValue(String, String) - Method in class org.apache.avro.data.TimeConversions.TimeMicrosConversion
- adjustAndSetValue(String, String) - Method in class org.apache.avro.data.TimeConversions.TimeMillisConversion
- adjustAndSetValue(String, String) - Method in class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
- adjustAndSetValue(String, String) - Method in class org.apache.avro.data.TimeConversions.TimestampMillisConversion
- adjustAndSetValue(String, String) - Method in class org.apache.avro.data.TimeConversions.TimestampNanosConversion
- adjustments - Variable in class org.apache.avro.io.parsing.Symbol.EnumAdjustAction
- adjustments - Variable in class org.apache.avro.Resolver.EnumAdjust
- 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.
- afterVisitNonTerminal(Schema) - Method in class org.apache.avro.compiler.schema.CloningVisitor
- afterVisitNonTerminal(Schema) - Method in interface org.apache.avro.compiler.schema.SchemaVisitor
-
Invoked for schemas with children after its children have been visited.
- afterVisitNonTerminal(Schema) - Method in class org.apache.avro.util.SchemaResolver.IsResolvedSchemaVisitor
- afterVisitNonTerminal(Schema) - Method in class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- afterVisitNonTerminal(Schema) - Method in interface org.apache.avro.util.SchemaVisitor
-
Invoked for schemas with children after its children have been visited.
- alias() - Element in annotation type org.apache.avro.reflect.AvroAlias
- aliases - Variable in class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
- aliases() - Method in class org.apache.avro.Schema.Field
-
Return the defined aliases as an unmodifiable Set.
- aliases(String...) - Method in class org.apache.avro.SchemaBuilder.NamedBuilder
-
configure this type's optional name aliases
- AllowNull() - Constructor for class org.apache.avro.reflect.ReflectData.AllowNull
- ALTERNATIVE - Enum constant in enum org.apache.avro.io.parsing.Symbol.Kind
-
non-terminal to represent the union
- and() - Method in class org.apache.avro.SchemaBuilder.UnionAccumulator
-
Add an additional type to this union
- append(D) - Method in class org.apache.avro.file.DataFileWriter
-
Append a datum to the file.
- append(List<ByteBuffer>) - Method in class org.apache.avro.util.ByteBufferOutputStream
-
Append a list of ByteBuffers to this stream.
- append(K, V) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
-
Appends a record to the SortedKeyValueFile.
- appendAllFrom(DataFileStream<D>, boolean) - Method in class org.apache.avro.file.DataFileWriter
-
Appends data from another file. otherFile must have the same schema.
- 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.
- AppendWriteException(Exception) - Constructor for exception class org.apache.avro.file.DataFileWriter.AppendWriteException
- 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 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 - Static variable in class org.apache.avro.idl.IdlLexer
- Array - Static variable in class org.apache.avro.idl.IdlParser
- Array(int, Schema) - Constructor for class org.apache.avro.generic.GenericData.Array
- Array(Schema, Collection<T>) - Constructor for class org.apache.avro.generic.GenericData.Array
- Array() - Method in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- Array() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- ARRAY - Enum constant in enum org.apache.avro.Schema.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
- ArrayBuilder(SchemaBuilder.Completion<R>, SchemaBuilder.NameContext) - Constructor for class org.apache.avro.SchemaBuilder.ArrayBuilder
- 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
- ArrayPositionPredicate - Class in org.apache.avro.path
-
Returns items by their position (numeric index) in an array
- ArrayPositionPredicate(long) - Constructor for class org.apache.avro.path.ArrayPositionPredicate
- arraySize - Variable in class org.apache.avro.perf.test.BasicArrayState
- ArrayTest - Class in org.apache.avro.perf.test.basic
- ArrayTest() - Constructor for class org.apache.avro.perf.test.basic.ArrayTest
- ArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- ArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- ArrayTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType
- ArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B1
- ArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- ArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B3
- ArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType
- ArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B1
- ArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- ArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B3
- ArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType
- ArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B1
- ArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- ArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B3
- ArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- ArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- arrayType() - Method in class org.apache.avro.idl.IdlParser
- arrayType() - Method in class org.apache.avro.idl.IdlParser.PlainTypeContext
- ArrayTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.ArrayTypeContext
- asByteBuffer() - Method in class org.apache.avro.util.NonCopyingByteArrayOutputStream
-
Get the contents of this ByteArrayOutputStream wrapped as a ByteBuffer.
- ASCENDING - Enum constant in enum org.apache.avro.Schema.Field.Order
- asString(byte[], Charset) - Static method in class org.apache.avro.util.UtfTextUtils
- At - Static variable in class org.apache.avro.idl.IdlLexer
- At - Static variable in class org.apache.avro.idl.IdlParser
- At() - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- AvroAlias - Annotation Type in org.apache.avro.reflect
-
Adds the given name and space as an alias to the schema.
- AvroAliases - Annotation Type in org.apache.avro.reflect
- 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.
- 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.BooleanWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts BooleanWritables into Booleans.
- AvroDatumConverterFactory.BytesWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts BytesWritables into ByteBuffers.
- AvroDatumConverterFactory.ByteWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts ByteWritables into GenericFixed of size 1.
- AvroDatumConverterFactory.DoubleWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts DoubleWritables into Doubles.
- AvroDatumConverterFactory.FloatWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts FloatWritables into Floats.
- AvroDatumConverterFactory.IntWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts IntWritables into Ints.
- AvroDatumConverterFactory.LongWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts LongWritables into Longs.
- AvroDatumConverterFactory.NullWritableConverter - Class in org.apache.avro.hadoop.io
-
Converts NullWritables into Nulls.
- AvroDatumConverterFactory.TextConverter - Class in org.apache.avro.hadoop.io
-
Converts Text into CharSequences.
- AvroDefault - Annotation Type in org.apache.avro.reflect
-
Specifies a default value for a field as a JSON string.
- AvroDeserializer<T,
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.
- AvroDoc - Annotation Type in org.apache.avro.reflect
-
Sets the avrodoc for this java field.
- 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.
- AvroGrpcClient - Class in org.apache.avro.grpc
-
Component that sets up a gRPC client for Avro's IDL and Serialization.
- AvroGrpcServer - Class in org.apache.avro.grpc
-
Provides components to set up a gRPC Server for Avro's IDL and serialization.
- AvroGrpcUtils - Class in org.apache.avro.grpc
-
Utility methods for using Avro IDL and serialization with gRPC.
- 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
- AvroInputStream - Class in org.apache.avro.grpc
-
An
InputStream
backed by Avro RPC request/response that can drained to aOutputStream
. - AvroInputStream() - Constructor for class org.apache.avro.grpc.AvroInputStream
- AvroInputStream.CountingOutputStream - Class in org.apache.avro.grpc
-
An
OutputStream
that writes to a targetOutputStream
and provides total number of bytes written to it. - 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 withAvroJob
. - AvroKeyComparator<T> - Class in org.apache.avro.mapred
-
The
RawComparator
used by jobs configured withAvroJob
. - AvroKeyComparator() - Constructor for class org.apache.avro.hadoop.io.AvroKeyComparator
- AvroKeyComparator() - Constructor for class org.apache.avro.mapred.AvroKeyComparator
- AvroKeyDeserializer<D> - Class in org.apache.avro.hadoop.io
-
Deserializes AvroKey objects within Hadoop.
- AvroKeyDeserializer(Schema, Schema, ClassLoader) - Constructor for class org.apache.avro.hadoop.io.AvroKeyDeserializer
-
Constructor.
- AvroKeyDeserializer(Schema, Schema, DatumReader<D>) - Constructor for class org.apache.avro.hadoop.io.AvroKeyDeserializer
-
Constructor.
- AvroKeyInputFormat<T> - Class in org.apache.avro.mapreduce
-
A MapReduce InputFormat that can handle Avro container files.
- AvroKeyInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyInputFormat
- AvroKeyOutputFormat<T> - Class in org.apache.avro.mapreduce
-
FileOutputFormat for writing Avro container files.
- AvroKeyOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat
-
Constructor.
- AvroKeyOutputFormat(AvroKeyOutputFormat.RecordWriterFactory) - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat
-
Constructor.
- AvroKeyOutputFormat.RecordWriterFactory<T> - Class in org.apache.avro.mapreduce
-
A factory for creating record writers.
- AvroKeyRecordReader<T> - Class in org.apache.avro.mapreduce
-
Reads records from an input split representing a chunk of an Avro container file.
- AvroKeyRecordReader(Schema) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordReader
-
Constructor.
- AvroKeyRecordWriter<T> - Class in org.apache.avro.mapreduce
-
Writes Avro records to an Avro container file output stream.
- AvroKeyRecordWriter(Schema, GenericData, CodecFactory, OutputStream) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordWriter
-
Constructor.
- AvroKeyRecordWriter(Schema, GenericData, CodecFactory, OutputStream, int) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordWriter
-
Constructor.
- AvroKeyValue<K,
V> - Class in org.apache.avro.hadoop.io -
A helper object for working with the Avro generic records that are used to store key/value pairs in an Avro container file.
- AvroKeyValue(GenericRecord) - Constructor for class org.apache.avro.hadoop.io.AvroKeyValue
-
Wraps a GenericRecord that is a key value pair.
- AvroKeyValue.Iterator<K,
V> - Class in org.apache.avro.hadoop.io -
A wrapper for iterators over GenericRecords that are known to be KeyValue records.
- AvroKeyValueInputFormat<K,
V> - Class in org.apache.avro.mapreduce -
A MapReduce InputFormat that reads from Avro container files of key/value generic records.
- AvroKeyValueInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyValueInputFormat
- AvroKeyValueOutputFormat<K,
V> - Class in org.apache.avro.mapreduce -
FileOutputFormat for writing Avro container files of key/value pairs.
- AvroKeyValueOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyValueOutputFormat
- AvroKeyValueRecordReader<K,
V> - Class in org.apache.avro.mapreduce -
Reads Avro generic records from an Avro container file, where the records contain two fields: 'key' and 'value'.
- AvroKeyValueRecordReader(Schema, Schema) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordReader
-
Constructor.
- AvroKeyValueRecordWriter<K,
V> - Class in org.apache.avro.mapreduce -
Writes key/value pairs to an Avro container file.
- AvroKeyValueRecordWriter(AvroDatumConverter<K, ?>, AvroDatumConverter<V, ?>, GenericData, CodecFactory, OutputStream) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
-
Constructor.
- AvroKeyValueRecordWriter(AvroDatumConverter<K, ?>, AvroDatumConverter<V, ?>, GenericData, CodecFactory, OutputStream, int) - 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.
- AvroMeta.AvroMetas - Annotation Type in org.apache.avro.reflect
- AvroMissingFieldException - Exception Class in org.apache.avro
-
Avro exception in case of missing fields.
- AvroMissingFieldException(String, Schema.Field) - Constructor for exception class org.apache.avro.AvroMissingFieldException
- AvroMultipleInputs - Class in org.apache.avro.mapred
-
This class supports Avro-MapReduce jobs that have multiple input paths with a different
Schema
andAvroMapper
for each path. - AvroMultipleInputs() - Constructor for class org.apache.avro.mapred.AvroMultipleInputs
- AvroMultipleOutputs - Class in org.apache.avro.mapred
-
The AvroMultipleOutputs class simplifies writing Avro output data to multiple outputs
- AvroMultipleOutputs - Class in org.apache.avro.mapreduce
-
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(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(FileReader<T>, FileSplit) - Constructor for class org.apache.avro.mapred.AvroRecordReader
- AvroRecordReader(JobConf, FileSplit) - Constructor for class org.apache.avro.mapred.AvroRecordReader
- AvroRecordReaderBase<K,
V, - Class in org.apache.avro.mapreduceT> -
Abstract base class for
RecordReader
s that read Avro container files. - AvroRecordReaderBase(Schema) - Constructor for class org.apache.avro.mapreduce.AvroRecordReaderBase
-
Constructor.
- AvroReducer<K,
V, - Class in org.apache.avro.mapredOUT> -
A reducer for Avro data.
- AvroReducer() - Constructor for class org.apache.avro.mapred.AvroReducer
- AvroRemoteException - Exception Class in org.apache.avro
-
Base class for exceptions thrown to client by server.
- AvroRemoteException() - Constructor for exception class org.apache.avro.AvroRemoteException
- AvroRemoteException(Object) - Constructor for exception class org.apache.avro.AvroRemoteException
- AvroRemoteException(Object, Throwable) - Constructor for exception class org.apache.avro.AvroRemoteException
- AvroRemoteException(Throwable) - Constructor for exception class org.apache.avro.AvroRemoteException
- AvroRequestMarshaller - Class in org.apache.avro.grpc
-
Marshaller for Avro RPC request.
- AvroRequestMarshaller(Protocol.Message) - Constructor for class org.apache.avro.grpc.AvroRequestMarshaller
- AvroResponseMarshaller - Class in org.apache.avro.grpc
-
Marshaller for Avro RPC response.
- AvroResponseMarshaller(Protocol.Message) - Constructor for class org.apache.avro.grpc.AvroResponseMarshaller
- AvroRuntimeException - Exception Class in org.apache.avro
-
Base Avro exception.
- AvroRuntimeException(String) - Constructor for exception class org.apache.avro.AvroRuntimeException
- AvroRuntimeException(String, Throwable) - Constructor for exception class org.apache.avro.AvroRuntimeException
- AvroRuntimeException(Throwable) - Constructor for exception class 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.
- Avro schemas as LL(1) CFG definitions - Search tag in package org.apache.avro.io.parsing
- Section
- AvroSequenceFile - Class in org.apache.avro.hadoop.io
-
A wrapper around a Hadoop
SequenceFile
that also supports reading and writing Avro data. - AvroSequenceFile.Reader - Class in org.apache.avro.hadoop.io
-
A reader for SequenceFiles that may contain Avro data.
- AvroSequenceFile.Reader.Options - Class in org.apache.avro.hadoop.io
-
A helper class to encapsulate the options that can be used to construct a Reader.
- AvroSequenceFile.Writer - Class in org.apache.avro.hadoop.io
-
A writer for an uncompressed SequenceFile that supports Avro data.
- AvroSequenceFile.Writer.Options - Class in org.apache.avro.hadoop.io
-
A helper class to encapsulate the options that can be used to construct a Writer.
- AvroSequenceFileInputFormat<K,
V> - Class in org.apache.avro.mapreduce -
An input format for reading from AvroSequenceFiles (sequence files that support Avro data).
- AvroSequenceFileInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroSequenceFileInputFormat
- AvroSequenceFileInputFormat.AvroSequenceFileRecordReader - Class in org.apache.avro.mapreduce
-
Reads records from a SequenceFile that supports Avro data.
- AvroSequenceFileOutputFormat<K,
V> - Class in org.apache.avro.mapreduce -
A sequence file output format that knows how to write AvroKeys and AvroValues in addition to Writables.
- AvroSequenceFileOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroSequenceFileOutputFormat
- AvroSequenceFileRecordReader() - Constructor for class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
- AvroSerialization<T> - Class in org.apache.avro.hadoop.io
-
The
Serialization
used by jobs configured withAvroJob
. - AvroSerialization<T> - Class in org.apache.avro.mapred
-
The
Serialization
used by jobs configured withAvroJob
. - AvroSerialization() - Constructor for class org.apache.avro.hadoop.io.AvroSerialization
- 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
- 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, - Class in org.apache.trevni.avro.mapreduceT> -
Abstract base class for
RecordReader
s that read Trevni container files. - AvroTrevniRecordReaderBase() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
- AvroTrevniRecordWriterBase<K,
V, - Class in org.apache.trevni.avro.mapreduceT> -
Abstract base class for
RecordWriter
s that writes Trevni container files. - AvroTrevniRecordWriterBase(TaskAttemptContext) - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
-
Constructor.
- AvroTypeException - Exception Class in org.apache.avro
-
Thrown when an illegal type is used.
- AvroTypeException(String) - Constructor for exception class org.apache.avro.AvroTypeException
- AvroTypeException(String, Throwable) - Constructor for exception class 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.
- AvroWrapperConverter(Schema) - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.AvroWrapperConverter
- 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
- BadHeaderException - Exception Class in org.apache.avro.message
-
Exception thrown by a
MessageDecoder
when a message header is not recognized. - BadHeaderException(String) - Constructor for exception class org.apache.avro.message.BadHeaderException
- BaseDecoder() - Constructor for class org.apache.avro.message.MessageDecoder.BaseDecoder
- BaseFieldTypeBuilder(SchemaBuilder.FieldBuilder<R>, SchemaBuilder.CompletionWrapper) - Constructor for class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
- BasicArrayState - Class in org.apache.avro.perf.test
- BasicArrayState(int) - Constructor for class org.apache.avro.perf.test.BasicArrayState
- BasicRecord - Class in org.apache.avro.perf.test
- BasicRecord() - Constructor for class org.apache.avro.perf.test.BasicRecord
- BasicRecord(Random) - Constructor for class org.apache.avro.perf.test.BasicRecord
- BasicState - Class in org.apache.avro.perf.test
- BasicState() - Constructor for class org.apache.avro.perf.test.BasicState
- BATCH_SIZE - Static variable in class org.apache.avro.perf.test.BasicState
- BFalse - Static variable in class org.apache.avro.idl.IdlLexer
- BFalse - Static variable in class org.apache.avro.idl.IdlParser
- BFalse() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- BFalse() - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- bigDecimal() - Static method in class org.apache.avro.LogicalTypes
-
Create a Big Decimal LogicalType that can accept any precision and scale
- BigDecimalConversion() - Constructor for class org.apache.avro.Conversions.BigDecimalConversion
- BigRecord - Class in org.apache.avro.perf.test
- BigRecord() - Constructor for class org.apache.avro.perf.test.BigRecord
- BigRecord(Random) - Constructor for class org.apache.avro.perf.test.BigRecord
- 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(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
- 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 - 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
- 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. - BinaryEncoder - Class in org.apache.avro.io
-
An abstract
Encoder
for Avro's binary encoding. - BinaryEncoder() - Constructor for class org.apache.avro.io.BinaryEncoder
- 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
- BinaryMessageDecoder<D> - Class in org.apache.avro.message
-
A
MessageDecoder
that reads a binary-encoded datum. - BinaryMessageDecoder(GenericData, Schema) - Constructor for class org.apache.avro.message.BinaryMessageDecoder
-
Creates a new
BinaryMessageEncoder
that uses the givendata model
to construct datum instances described by theschema
. - BinaryMessageDecoder(GenericData, Schema, SchemaStore) - Constructor for class org.apache.avro.message.BinaryMessageDecoder
-
Creates a new
BinaryMessageEncoder
that uses the givendata model
to construct datum instances described by theschema
. - BinaryMessageEncoder<D> - Class in org.apache.avro.message
-
A
MessageEncoder
that adds a header and 8-byte schema fingerprint to each datum encoded as binary. - BinaryMessageEncoder(GenericData, Schema) - Constructor for class org.apache.avro.message.BinaryMessageEncoder
-
Creates a new
BinaryMessageEncoder
that uses the givendata model
to deconstruct datum instances described by theschema
. - BinaryMessageEncoder(GenericData, Schema, boolean) - Constructor for class org.apache.avro.message.BinaryMessageEncoder
-
Creates a new
BinaryMessageEncoder
that uses the givendata model
to deconstruct datum instances described by theschema
. - 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(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. - BlockingBinaryEncoder - Class in org.apache.avro.io
-
A
BinaryEncoder
implementation that writes large arrays and maps as a sequence of blocks. - blockingDirectBinaryEncoder(OutputStream, BinaryEncoder) - Method in class org.apache.avro.io.EncoderFactory
-
Creates or reinitializes a
BlockingDirectBinaryEncoder
with the OutputStream provided as the destination for written data. - BlockingDirectBinaryEncoder - Class in org.apache.avro.io
-
An
Encoder
for Avro's binary encoding that does not buffer output. - BlockingDirectBinaryEncoder(OutputStream) - Constructor for class org.apache.avro.io.BlockingDirectBinaryEncoder
-
Create a writer that sends its output to the underlying stream
out
. - body - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- body - Variable in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- Boolean - Static variable in class org.apache.avro.idl.IdlLexer
- Boolean - Static variable in class org.apache.avro.idl.IdlParser
- Boolean() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Boolean() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- BOOLEAN - Enum constant in enum org.apache.avro.Schema.Type
- BOOLEAN - Enum constant in enum org.apache.trevni.ValueType
- BOOLEAN - Static variable in class org.apache.avro.io.parsing.Symbol
- BooleanArray(int, Schema) - Constructor for class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- BooleanArray(Schema, Collection<Boolean>) - Constructor for class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- 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
- BooleanTest - Class in org.apache.avro.perf.test.basic
- BooleanTest() - Constructor for class org.apache.avro.perf.test.basic.BooleanTest
- BooleanTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- BooleanTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- BooleanTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType
- BooleanTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B1
- BooleanTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- BooleanTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B3
- BooleanTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType
- BooleanTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B1
- BooleanTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- BooleanTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B3
- BooleanTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType
- BooleanTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B1
- BooleanTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- BooleanTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BooleanTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B3
- BooleanTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- BooleanTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- 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.
- BooleanWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BooleanWritableConverter
-
Constructor.
- BOTH - Enum constant in enum org.apache.avro.ipc.HandshakeMatch
- BTrue - Static variable in class org.apache.avro.idl.IdlLexer
- BTrue - Static variable in class org.apache.avro.idl.IdlParser
- BTrue() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- BTrue() - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- 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. - 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
- 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 anInputStream
. - 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
inByteBuffer
s. - ByteBufferOutputStream() - Constructor for class org.apache.avro.util.ByteBufferOutputStream
- bytes() - Method in class org.apache.avro.generic.GenericData.Fixed
- bytes() - Method in interface org.apache.avro.generic.GenericFixed
-
Return the data.
- bytes() - Method in class org.apache.avro.specific.SpecificFixed
- bytes(byte[]) - Method in class org.apache.avro.generic.GenericData.Fixed
- bytes(byte[]) - Method in class org.apache.avro.specific.SpecificFixed
- Bytes - Static variable in class org.apache.avro.idl.IdlLexer
- Bytes - Static variable in class org.apache.avro.idl.IdlParser
- Bytes() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Bytes() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- BYTES - Enum constant in enum org.apache.avro.Schema.Type
- BYTES - Enum constant in enum org.apache.trevni.ValueType
- 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(String) - 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
- BytesTest - Class in org.apache.avro.perf.test.basic
- BytesTest() - Constructor for class org.apache.avro.perf.test.basic.BytesTest
- BytesTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- BytesTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- BytesTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType
- BytesTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B1
- BytesTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- BytesTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B3
- BytesTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType
- BytesTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B1
- BytesTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- BytesTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B3
- BytesTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType
- BytesTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B1
- BytesTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- BytesTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- BytesTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B3
- BytesTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- BytesTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- 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.
- BytesWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BytesWritableConverter
-
Constructor.
- ByteWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.ByteWritableConverter
-
Constructor.
- BZIP2_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
- bzip2Codec() - Static method in class org.apache.avro.file.CodecFactory
-
bzip2 codec.
- BZip2Codec - Class in org.apache.avro.file
-
Implements bzip2 compression and decompression.
- BZip2Codec - Class in org.apache.trevni
- BZip2Codec() - Constructor for class org.apache.avro.file.BZip2Codec
- BZip2Codec() - Constructor for class org.apache.trevni.BZip2Codec
C
- Cache() - Constructor for class org.apache.avro.message.SchemaStore.Cache
- calcAllArgConstructorParameterUnits(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Returns the number of parameter units required by fields for the AllArgsConstructor.
- calculateShift(int, int) - Static method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Calculate a shift value that can be used to create a power-of-two value between the specified maximum and minimum values.
- callback - Variable in class org.apache.avro.ipc.netty.NettyTransceiver.WriteFutureListener
- Callback<T> - Interface in org.apache.avro.ipc
-
Interface for receiving asynchronous callbacks.
- 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.
- canBeReadStrategy() - Method in class org.apache.avro.SchemaValidatorBuilder
-
Use a strategy that validates that a schema can be read by existing schema(s) according to the Avro default schema resolution.
- cancel(boolean) - Method in class org.apache.avro.ipc.CallFuture
- CanonicalSchemaFormatterFactory - Class in org.apache.avro
-
Schema formatter factory that supports the "Parsing Canonical Form".
- CanonicalSchemaFormatterFactory() - Constructor for class org.apache.avro.CanonicalSchemaFormatterFactory
- canReadStrategy() - Method in class org.apache.avro.SchemaValidatorBuilder
-
Use a strategy that validates that a schema can be used to read existing schema(s) according to the Avro default schema resolution.
- canReuse() - Method in interface org.apache.avro.io.FastReaderBuilder.FieldReader
- canReuse() - Method in class org.apache.avro.io.FastReaderBuilder.RecordReader
- canReuse() - Method in interface org.apache.avro.io.FastReaderBuilder.ReusingFieldReader
- 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
- channelInactive(ChannelHandlerContext) - Method in class org.apache.avro.ipc.netty.NettyTransceiver.NettyClientAvroHandler
- channelNames - Static variable in class org.apache.avro.idl.IdlLexer
- channelRead0(ChannelHandlerContext, NettyTransportCodec.NettyDataPack) - Method in class org.apache.avro.ipc.netty.NettyTransceiver.NettyClientAvroHandler
- charAt(int) - Method in class org.apache.avro.util.Utf8
- CharSequence - Enum constant in enum org.apache.avro.generic.GenericData.StringType
- charts - Variable in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
- checkMaxBytesLength(long) - Static method in exception class org.apache.avro.SystemLimitException
-
Check to ensure that reading the bytes is within the specified limits.
- checkMaxCollectionLength(long, long) - Static method in exception class org.apache.avro.SystemLimitException
-
Check to ensure that reading the specified number of items remains within the specified limits.
- checkMaxStringLength(long) - Static method in exception class org.apache.avro.SystemLimitException
-
Check to ensure that reading the string size is within the specified limits.
- 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.
- 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() - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- clear() - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- clear() - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- clear() - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- clear() - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- clear() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- clear() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Segment
-
Clear all items from this segment.
- clear() - Method in class org.apache.avro.util.WeakIdentityHashMap
- clear(int) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Clears the value of the given field.
- 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.
- 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.
- clearMatch() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Clears the value of the 'match' 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.
- 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.
- clearValue() - Method in interface org.apache.avro.data.ErrorBuilder
-
Clears the value
- clearValue() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
- CLIENT - Enum constant in enum org.apache.avro.ipc.HandshakeMatch
- clientFinishConnect(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
-
Called on the client after the initial RPC handshake
- 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
- 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
- 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
- CloningVisitor - Class in org.apache.avro.compiler.schema
-
this visitor will create a clone of the original Schema with docs and other nonessential fields stripped by default. what attributes are copied is customizable.
- CloningVisitor(CloningVisitor.PropertyCopier, boolean, Schema) - Constructor for class org.apache.avro.compiler.schema.CloningVisitor
- CloningVisitor(Schema) - Constructor for class org.apache.avro.compiler.schema.CloningVisitor
-
copy only serialization necessary fields.
- CloningVisitor.PropertyCopier - Interface in org.apache.avro.compiler.schema
- 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.grpc.AvroInputStream.CountingOutputStream
- 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.jetty.HttpServer
- close() - Method in class org.apache.avro.ipc.netty.NettyServer
- close() - Method in class org.apache.avro.ipc.netty.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() - 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() - Method in class org.apache.trevni.ColumnFileReader
- close() - Method in class org.apache.trevni.InputFile
- close(boolean) - Method in class org.apache.avro.ipc.netty.NettyTransceiver
-
Closes this transceiver and disconnects from the remote peer.
- close(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyRecordWriter
- close(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
- close(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
- 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(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.
- collect(T) - Method in class org.apache.avro.mapred.AvroCollector
- Colon - Static variable in class org.apache.avro.idl.IdlLexer
- Colon - Static variable in class org.apache.avro.idl.IdlParser
- Colon() - Method in class org.apache.avro.idl.IdlParser.JsonPairContext
- 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> - Class in org.apache.trevni
-
An iterator over column values.
- CombineAvroKeyValueFileInputFormat<K,
V> - Class in org.apache.avro.mapreduce -
A combine avro keyvalue file input format that can combine small avro files into mappers.
- CombineAvroKeyValueFileInputFormat() - Constructor for class org.apache.avro.mapreduce.CombineAvroKeyValueFileInputFormat
- Comma - Static variable in class org.apache.avro.idl.IdlLexer
- Comma - Static variable in class org.apache.avro.idl.IdlParser
- Comma() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- Comma() - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- Comma() - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- Comma() - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- Comma() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- Comma() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- Comma() - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- Comma(int) - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- Comma(int) - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- Comma(int) - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- Comma(int) - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- Comma(int) - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- Comma(int) - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- commit() - Method in class org.apache.avro.ParseContext
- commit(Schema) - Method in class org.apache.avro.ParseContext
- 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) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.avro.mapred.AvroKeyComparator
- compare(byte[], int, int, byte[], int, int, Schema) - Static method in class org.apache.avro.io.BinaryData
-
Compare binary encoded data.
- 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(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
- compare(AvroKey<T>, AvroKey<T>) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
- compare(AvroWrapper<T>, AvroWrapper<T>) - Method in class org.apache.avro.mapred.AvroKeyComparator
- compare(T, T) - Method in class org.apache.avro.hadoop.util.AvroCharSequenceComparator
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.avro.io.BinaryData
-
Lexicographically compare bytes.
- compareMaps(Map<?, ?>, Map<?, ?>) - Method in class org.apache.avro.generic.GenericData
- compareTo(GenericArray<T>) - Method in class org.apache.avro.generic.GenericData.AbstractArray
- compareTo(GenericData.EnumSymbol) - 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(Pair) - Method in class org.apache.avro.mapred.Pair
- compareTo(SpecificFixed) - Method in class org.apache.avro.specific.SpecificFixed
- compareTo(SpecificRecord) - Method in class org.apache.avro.specific.SpecificRecordBase
- compareTo(Utf8) - Method in class org.apache.avro.util.Utf8
- compatible() - Static method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
-
Returns a details object representing a compatible schema pair.
- COMPATIBLE - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaCompatibilityType
- compileProtocol(File[], File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java interface and classes for a number of protocol files.
- compileProtocol(File, File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java interface and classes for a protocol.
- compileSchema(File[], File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java classes for a number of schema files.
- compileSchema(File, File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java classes for a schema.
- compileToDestination(File, File) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generate output under dst, unless existing file is newer than src.
- 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.
- 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.DeflateCodec
- compress(ByteBuffer) - Method in class org.apache.avro.file.SnappyCodec
- compress(ByteBuffer) - Method in class org.apache.avro.file.XZCodec
- compress(ByteBuffer) - Method in class org.apache.avro.file.ZstandardCodec
- computeIfAbsent(ConcurrentMap<K, V>, K, Function<K, V>) - Static method in class org.apache.avro.util.MapUtil
-
A temporary workaround for Java 8 specific performance issue JDK-8161372 .
This class should be removed once we drop Java 8 support. - computeOffset(ByteBuffer) - Static method in class org.apache.avro.file.Codec
- computeOffset(ByteBuffer) - Static method in class org.apache.trevni.BZip2Codec
- 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
- ConcurrentReferenceHashMap<K,
V> - Class in org.apache.avro.util.springframework - ConcurrentReferenceHashMap() - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Create a new
ConcurrentReferenceHashMap
instance. - ConcurrentReferenceHashMap(int) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Create a new
ConcurrentReferenceHashMap
instance. - ConcurrentReferenceHashMap(int, float) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Create a new
ConcurrentReferenceHashMap
instance. - ConcurrentReferenceHashMap(int, float, int) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Create a new
ConcurrentReferenceHashMap
instance. - ConcurrentReferenceHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Create a new
ConcurrentReferenceHashMap
instance. - ConcurrentReferenceHashMap(int, int) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Create a new
ConcurrentReferenceHashMap
instance. - ConcurrentReferenceHashMap(int, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Create a new
ConcurrentReferenceHashMap
instance. - ConcurrentReferenceHashMap.Entry<K,
V> - Class in org.apache.avro.util.springframework -
A single map entry.
- ConcurrentReferenceHashMap.Reference<K,
V> - Interface in org.apache.avro.util.springframework -
A reference to an
ConcurrentReferenceHashMap.Entry
contained in the map. - ConcurrentReferenceHashMap.ReferenceManager - Class in org.apache.avro.util.springframework
-
Strategy class used to manage
References
. - ConcurrentReferenceHashMap.ReferenceType - Enum in org.apache.avro.util.springframework
-
Various reference types supported by this map.
- ConcurrentReferenceHashMap.Restructure - Enum in org.apache.avro.util.springframework
-
The types of restructuring that can be performed.
- ConcurrentReferenceHashMap.Segment - Class in org.apache.avro.util.springframework
-
A single segment used to divide the map to allow better concurrent performance.
- CONF_OUTPUT_CODEC - Static variable in class org.apache.avro.mapreduce.AvroJob
-
The configuration key for a job's output compression codec.
- configure(int) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Configure task.
- configure(InputStream) - Method in class org.apache.avro.io.JsonDecoder
-
Reconfigures this JsonDecoder to use the InputStream provided.
- configure(OutputStream) - Method in class org.apache.avro.io.JsonEncoder
-
Reconfigures this JsonEncoder to use the output stream provided.
- configure(OutputStream, boolean) - Method in class org.apache.avro.io.JsonEncoder
-
Reconfigures this JsonEncoder to use the output stream provided.
- configure(String) - Method in class org.apache.avro.io.JsonDecoder
-
Reconfigures this JsonDecoder to use the String provided for input.
- 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(TaskType, String, String) - Method in interface org.apache.avro.mapred.tether.InputProtocol
-
Configure the task.
- 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
- 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.
- Container(Schema, Schema, GenericData, Resolver.Action) - Constructor for class org.apache.avro.Resolver.Container
- CONTAINER - Enum constant in enum org.apache.avro.Resolver.Action.Type
- contains(String) - Method in class org.apache.avro.ParseContext
-
Tell whether this context contains a schema with the given name.
- containsKey(Object) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- 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
- CONTINUE - Enum constant in enum org.apache.avro.compiler.schema.SchemaVisitorAction
-
continue visit.
- CONTINUE - Enum constant in enum org.apache.avro.util.SchemaVisitor.SchemaVisitorAction
-
continue visit.
- conversion - Variable in class org.apache.avro.Resolver.Action
-
If the reader has a conversion that needs to be applied, it's stored here for fast access, otherwise this will be null.
- Conversion<T> - Class in org.apache.avro
-
Conversion between generic and logical type instances.
- Conversion() - Constructor for class org.apache.avro.Conversion
- conversionInstance(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- Conversions - Class in org.apache.avro
- Conversions() - Constructor for class org.apache.avro.Conversions
- Conversions.BigDecimalConversion - Class in org.apache.avro
- Conversions.DecimalConversion - Class in org.apache.avro
- Conversions.DurationConversion - Class in org.apache.avro
- Conversions.UUIDConversion - Class in org.apache.avro
- convert(INPUT) - Method in class org.apache.avro.hadoop.io.AvroDatumConverter
- convert(Object, Schema, LogicalType, Conversion<?>) - Method in class org.apache.avro.generic.GenericDatumReader
-
Convert an underlying representation of a logical type (such as a ByteBuffer) to a higher level object (such as a BigDecimal).
- convert(AvroWrapper<?>) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.AvroWrapperConverter
- convert(Schema, LogicalType, Conversion<T>, Object) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Convert a high level representation of a logical type (such as a BigDecimal) to its underlying representation object (such as a ByteBuffer).
- 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
- convertToLogicalType(Object, Schema, LogicalType, Conversion<?>) - Static method in class org.apache.avro.Conversions
-
Convert an underlying representation of a logical type (such as a ByteBuffer) to a higher level object (such as a BigDecimal).
- convertToRawType(Object, Schema, LogicalType, Conversion<T>) - Static method in class org.apache.avro.Conversions
-
Convert a high level representation of a logical type (such as a BigDecimal) to its underlying representation object (such as a ByteBuffer)
- copy(Schema.Field, Schema.Field) - Method in interface org.apache.avro.compiler.schema.CloningVisitor.PropertyCopier
- copy(Schema, Schema) - Method in interface org.apache.avro.compiler.schema.CloningVisitor.PropertyCopier
- copyAliases(Schema.Field, Schema.Field) - Static method in class org.apache.avro.compiler.schema.Schemas
- copyAliases(Schema, Schema) - Static method in class org.apache.avro.compiler.schema.Schemas
- copyLogicalTypes(Schema, Schema) - Static method in class org.apache.avro.compiler.schema.Schemas
- copyProperties(JsonProperties, JsonProperties) - Static method in class org.apache.avro.compiler.schema.Schemas
- copyProperties(Schema, Schema) - Method in class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- count(String, String, long) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Increment a task/job counter.
- CountingOutputStream(OutputStream) - Constructor for class org.apache.avro.grpc.AvroInputStream.CountingOutputStream
- create(Channel, Class<T>) - Static method in class org.apache.avro.grpc.AvroGrpcClient
-
Creates a gRPC client for Avro's interface with default
CallOptions
. - create(Channel, Class<T>, CallOptions) - Static method in class org.apache.avro.grpc.AvroGrpcClient
-
Creates a gRPC client for Avro's interface with provided
CallOptions
. - 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.Type) - Static method in class org.apache.avro.Schema
-
Create a schema for a primitive type.
- create(Schema, File) - Method in class org.apache.avro.file.DataFileWriter
-
Open a new file for data matching a schema with a random sync.
- create(Schema, OutputStream) - Method in class org.apache.avro.file.DataFileWriter
-
Open a new file for data matching a schema with a random sync.
- create(Schema, OutputStream, byte[]) - Method in class org.apache.avro.file.DataFileWriter
-
Open a new file for data matching a schema with an explicit sync.
- create(Schema, GenericData, CodecFactory, OutputStream, int) - Method in class org.apache.avro.mapreduce.AvroKeyOutputFormat.RecordWriterFactory
-
Creates a new record writer instance.
- 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(byte[], int, int, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
-
Deprecated.
- createBinaryDecoder(byte[], BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
-
Deprecated.
- createBinaryDecoder(InputStream, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
-
Deprecated.use the equivalent
DecoderFactory.binaryDecoder(InputStream, BinaryDecoder)
instead - createBytes(byte[]) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to create byte arrays from default values.
- createClassLoader() - Method in class org.apache.avro.mojo.AbstractAvroMojo
- 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) - Method in class org.apache.avro.io.FastReaderBuilder
- createDatumReader(Schema) - Method in class org.apache.avro.protobuf.ProtobufData
- createDatumReader(Schema) - Method in class org.apache.avro.reflect.ReflectData
- createDatumReader(Schema) - Method in class org.apache.avro.specific.SpecificData
- createDatumReader(Schema) - Method in class org.apache.avro.thrift.ThriftData
- createDatumReader(Schema, 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.io.FastReaderBuilder
- createDatumReader(Schema, Schema) - Method in class org.apache.avro.reflect.ReflectData
- createDatumReader(Schema, Schema) - Method in class org.apache.avro.specific.SpecificData
- 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
- createDecoder(SchemaStore) - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Create a new BinaryMessageDecoder instance for this class that uses the specified
SchemaStore
. - createDecoder(SchemaStore) - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Create a new BinaryMessageDecoder instance for this class that uses the specified
SchemaStore
. - createEnum(String, String, String, List<String>) - Static method in class org.apache.avro.Schema
-
Create an enum schema.
- createEnum(String, String, String, List<String>, String) - Static method in class org.apache.avro.Schema
-
Create an enum schema.
- 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, 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, byte[], 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.GenericDatumReader
-
Deprecated.As of Avro 1.6.0 this method has been moved to
GenericData.createFixed(Object, byte[], Schema)
- createFixed(Object, 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, Schema) - Method in class org.apache.avro.reflect.ReflectData
- createFixed(Object, Schema) - Method in class org.apache.avro.specific.SpecificData
- createFixed(String, String, String, int) - Static method in class org.apache.avro.Schema
-
Create a fixed schema.
- 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, Map<String, ?>, Schema) - Method in class org.apache.avro.Protocol
-
Create a one-way message.
- createMessage(String, String, Map<String, ?>, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Create a two-way message.
- createMessage(String, String, JsonProperties, Schema) - Method in class org.apache.avro.Protocol
-
Create a one-way message.
- createMessage(String, String, JsonProperties, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Create a two-way message.
- createMessage(String, String, Schema) - Method in class org.apache.avro.Protocol
-
Deprecated.
- createMessage(String, String, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Deprecated.
- createMessage(Protocol.Message, Schema) - Method in class org.apache.avro.Protocol
-
Create a one-way message using the
name
,doc
, andprops
ofm
. - createMessage(Protocol.Message, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Create a two-way message using the
name
,doc
, andprops
ofm
. - createNettyClientAvroHandler() - Method in class org.apache.avro.ipc.netty.NettyTransceiver
-
Creates a Netty ChannelUpstreamHandler for handling events on the Netty client channel.
- createNullSafeAnnotations - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
The createNullSafeAnnotations parameter adds JetBrains @Nullable and @NotNull annotations for fhe fields of the record.
- createOptionalGetters - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
The createOptionalGetters parameter enables generating the getOptional...
- 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(String, String, String, boolean) - Static method in class org.apache.avro.Schema
-
Create a named record schema.
- createRecord(String, String, String, boolean, List<Schema.Field>) - Static method in class org.apache.avro.Schema
-
Create a named record schema with fields already set.
- createRecord(List<Schema.Field>) - Static method in class org.apache.avro.Schema
-
Deprecated.This method allows to create Schema objects that cannot be parsed by
SchemaParser.parse(CharSequence)
. It will be removed in a future version of Avro. Better useSchema.createRecord(String, String, String, boolean, List)
to produce a fully qualified 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.avro.mapreduce.CombineAvroKeyValueFileInputFormat
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyInputFormat
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueInputFormat
- createReference(ConcurrentReferenceHashMap.Entry<K, V>, int, ConcurrentReferenceHashMap.Reference<K, V>) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.ReferenceManager
-
Factory method used to create a new
ConcurrentReferenceHashMap.Reference
. - createReferenceManager() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Factory method that returns the
ConcurrentReferenceHashMap<K,
.V>.ReferenceManager - 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.
- createSchemaDefaultValue(Type, Field, Schema) - Method in class org.apache.avro.reflect.ReflectData
-
Get default value for a schema field.
- 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. - createServiceDefinition(Class, Object) - Static method in class org.apache.avro.grpc.AvroGrpcServer
-
Creates a
ServerServiceDefinition
for Avro Interface and its implementation that can be passed a gRPC Server. - createSetters - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
Determines whether or not to create setters for the fields of the record.
- createString(Object) - Method in class org.apache.avro.generic.GenericData
-
Called to create an string value.
- createString(Object) - Method in class org.apache.avro.specific.SpecificData
- 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.
- createUnion(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.
- customConversions - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
A set of fully qualified class names of custom
Conversion
implementations to add to the compiler. - customDecode(ResolvingDecoder) - Method in class org.apache.avro.ipc.HandshakeRequest
- customDecode(ResolvingDecoder) - Method in class org.apache.avro.ipc.HandshakeResponse
- customDecode(ResolvingDecoder) - Method in class org.apache.avro.specific.SpecificRecordBase
- customEncode(Encoder) - Method in class org.apache.avro.ipc.HandshakeRequest
- customEncode(Encoder) - Method in class org.apache.avro.ipc.HandshakeResponse
- customEncode(Encoder) - Method in class org.apache.avro.specific.SpecificRecordBase
- 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
- customLogicalTypeFactories - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
A set of fully qualified class names of custom
LogicalTypes.LogicalTypeFactory
implementations to add to the compiler.
D
- d1 - Variable in class org.apache.avro.perf.test.BigRecord
- d11 - Variable in class org.apache.avro.perf.test.BigRecord
- Dash - Static variable in class org.apache.avro.idl.IdlLexer
- Dash - Static variable in class org.apache.avro.idl.IdlParser
- 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>, boolean, byte[]) - 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
- DataFileRepairTool - Class in org.apache.avro.tool
-
Recovers data from a corrupt Avro Data file
- DataFileRepairTool() - Constructor for class org.apache.avro.tool.DataFileRepairTool
- 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 uninitialized 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 Class in org.apache.avro.file
-
Thrown by
DataFileWriter.append(Object)
when an exception occurs while writing a datum to the buffer. - 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
- date() - Static method in class org.apache.avro.LogicalTypes
- Date - Static variable in class org.apache.avro.idl.IdlLexer
- Date - Static variable in class org.apache.avro.idl.IdlParser
- Date() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Date() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- 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
- DateConversion() - Constructor for class org.apache.avro.data.TimeConversions.DateConversion
- 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.
- decimal(int) - Static method in class org.apache.avro.LogicalTypes
-
Create a Decimal LogicalType with the given precision and scale 0
- decimal(int, int) - Static method in class org.apache.avro.LogicalTypes
-
Create a Decimal LogicalType with the given precision and scale
- Decimal - Static variable in class org.apache.avro.idl.IdlLexer
- Decimal - Static variable in class org.apache.avro.idl.IdlParser
- Decimal() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Decimal() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- DecimalConversion() - Constructor for class org.apache.avro.Conversions.DecimalConversion
- decode(byte[]) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
- decode(byte[]) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a byte array.
- decode(byte[], D) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
- decode(byte[], D) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a byte array.
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.avro.ipc.netty.NettyTransportCodec.NettyFrameDecoder
-
decode buffer to NettyDataPack
- decode(InputStream) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
- decode(InputStream) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from an InputStream.
- decode(InputStream, D) - Method in class org.apache.avro.message.BinaryMessageDecoder
- decode(InputStream, D) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from an InputStream.
- decode(InputStream, D) - Method in class org.apache.avro.message.RawMessageDecoder
- decode(ByteBuffer) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
- decode(ByteBuffer) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a ByteBuffer.
- decode(ByteBuffer, D) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
- decode(ByteBuffer, D) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a ByteBuffer.
- decode(ArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.ArrayTest
- decode(BooleanTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.BooleanTest
- decode(BytesTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.BytesTest
- decode(DoubleTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.DoubleTest
- decode(FloatTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.FloatTest
- decode(IntTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.IntTest
- decode(LongTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.LongTest
- decode(MapTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.MapTest
- decode(SmallLongTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.SmallLongTest
- decode(StringTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.StringTest
- decode(RecordTest.TestStateDecode, Blackhole) - Method in class org.apache.avro.perf.test.record.RecordTest
- decode(RecordWithDefaultTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.RecordWithDefaultTest
- decode(RecordWithOutOfOrderTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest
- decode(RecordWithPromotionTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.RecordWithPromotionTest
- decode(ResolvingRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.ResolvingRecordTest
- decode(ValidatingRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest
- decode(Blackhole, ExtendedEnumTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest
- decode(Blackhole, UnchangedUnionTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest
- decode(Blackhole, GenericNestedFakeTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest
- decode(Blackhole, GenericNestedTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericNestedTest
- decode(Blackhole, GenericStringTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericStringTest
- decode(Blackhole, GenericTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericTest
- decode(Blackhole, GenericWithDefaultTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest
- decode(Blackhole, GenericWithOutOfOrderTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest
- decode(Blackhole, GenericWithPromotionTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericWithPromotionTest
- decode(Blackhole, ReflectBigRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest
- decode(Blackhole, ReflectDoubleArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest
- decode(Blackhole, ReflectFloatArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest
- decode(Blackhole, ReflectIntArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest
- decode(Blackhole, ReflectLargeFloatArrayBlockedTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest
- decode(Blackhole, ReflectLargeFloatArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest
- decode(Blackhole, ReflectLongArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest
- decode(Blackhole, ReflectNestedFloatArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest
- decode(Blackhole, ReflectNestedObjectArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest
- decode(Blackhole, ReflectRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- 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
Decoder
s. - 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.DeflateCodec
- decompress(ByteBuffer) - Method in class org.apache.avro.file.SnappyCodec
- decompress(ByteBuffer) - Method in class org.apache.avro.file.XZCodec
- decompress(ByteBuffer) - Method in class org.apache.avro.file.ZstandardCodec
- deepCopy(Schema, T) - Method in class org.apache.avro.generic.GenericData
-
Makes a deep copy of a value given its schema.
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.avro.file.BZip2Codec
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.trevni.BZip2Codec
- DEFAULT_COMPRESSION - Static variable in class org.apache.avro.file.XZCodec
- DEFAULT_COMPRESSION - Static variable in class org.apache.avro.file.ZstandardCodec
- DEFAULT_CONNECTION_TIMEOUT_MILLIS - Static variable in class org.apache.avro.ipc.netty.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_SYNC_INTERVAL - Static variable in class org.apache.avro.file.DataFileConstants
- DEFAULT_TCP_NODELAY_VALUE - Static variable in class org.apache.avro.ipc.netty.NettyTransceiver
- DEFAULT_USE_BUFFERPOOL - Static variable in class org.apache.avro.file.ZstandardCodec
- DEFAULT_XZ_LEVEL - Static variable in class org.apache.avro.file.CodecFactory
- DEFAULT_ZSTANDARD_BUFFERPOOL - Static variable in class org.apache.avro.file.CodecFactory
- DEFAULT_ZSTANDARD_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 - defaults - Variable in class org.apache.avro.Resolver.RecordAdjust
-
Contains the default values to be used for the last readerOrder.length-firstDefault fields in rearderOrder.
- defaultStartAction(byte[]) - Static method in class org.apache.avro.io.parsing.Symbol
- DefaultStartAction(byte[]) - Constructor for class org.apache.avro.io.parsing.Symbol.DefaultStartAction
-
Deprecated.
- defaultSymbol - Variable in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- defaultSymbol(String) - Method in class org.apache.avro.SchemaBuilder.EnumBuilder
-
Set the default value of the enum.
- defaultSymbolName - Variable in class org.apache.avro.idl.IdlParser.EnumDefaultContext
- defaultVal() - Method in class org.apache.avro.Schema.Field
- defaultValue - Variable in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- defaultValue(Schema.Field) - Method in class org.apache.avro.data.RecordBuilderBase
-
Gets the default value of the given field, if any.
- 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. compressionLevel should be between 1 and 9, inclusive.
- DeflateCodec - Class in org.apache.avro.file
-
Implements DEFLATE (RFC1951) compression and decompression.
- DeflateCodec(int) - Constructor for class org.apache.avro.file.DeflateCodec
- 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
- DESCENDING - Enum constant in enum org.apache.avro.Schema.Field.Order
- describe(Object) - Static method in class org.apache.avro.util.SchemaUtil
- describe(Schema) - Static method in class org.apache.avro.util.SchemaUtil
- deserialize(T) - Method in class org.apache.avro.hadoop.io.AvroDeserializer
- detectUtfCharset(byte[]) - Static method in class org.apache.avro.util.UtfTextUtils
-
Assuming UTF encoded bytes, detect the UTF variant (8/16/32 bits, big/little endian).
- 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(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. - DirectBinaryEncoder - Class in org.apache.avro.io
-
An
Encoder
for Avro's binary encoding that does not buffer output. - DirectBinaryEncoder(OutputStream) - Constructor for class org.apache.avro.io.DirectBinaryEncoder
-
Create a writer that sends its output to the underlying stream
out
. - DO_NOTHING - Enum constant in enum org.apache.avro.Resolver.Action.Type
- 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 - Variable in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- doc - Variable in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- doc - Variable in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- doc - Variable in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- doc - Variable in class org.apache.avro.idl.IdlParser.FormalParameterContext
- doc - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- doc - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- doc - Variable in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- doc - Variable in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- 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
- DocComment - Static variable in class org.apache.avro.idl.IdlLexer
- DocComment - Static variable in class org.apache.avro.idl.IdlParser
- DocComment() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.FormalParameterContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- DocComment() - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- 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(File, Collection<Schema>, File) - Method in class org.apache.avro.mojo.AbstractAvroMojo
- doCompile(File, Protocol, File) - Method in class org.apache.avro.mojo.AbstractAvroMojo
- doCompile(String[], File, File) - Method in class org.apache.avro.mojo.AbstractAvroMojo
- doCompile(String[], File, File) - Method in class org.apache.avro.mojo.SchemaMojo
- doCompile(String, File, File) - Method in class org.apache.avro.mojo.AbstractAvroMojo
- doCompile(String, File, File) - Method in class org.apache.avro.mojo.IDLMojo
- doCompile(String, File, File) - Method in class org.apache.avro.mojo.ProtocolMojo
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.stats.StatsServlet
- DoNothing(Schema, Schema, GenericData) - Constructor for class org.apache.avro.Resolver.DoNothing
- doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.ResponderServlet
- 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.
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.ArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.BooleanTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.BytesTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.DoubleTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.FloatTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.IntTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.LongTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.MapTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.SmallLongTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.StringTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericStringTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericWithPromotionTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordWithDefaultTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordWithPromotionTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.ResolvingRecordTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateDecode
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateDecode
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ArrayTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BooleanTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BooleanTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BytesTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BytesTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.DoubleTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.DoubleTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.FloatTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.FloatTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.IntTest.TestStateDecode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.IntTest.TestStateEncode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.LongTest.TestStateDecode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.LongTest.TestStateEncode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.MapTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.MapTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.SmallLongTest.TestStateDecode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.SmallLongTest.TestStateEncode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.StringTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.StringTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericStringTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericStringTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithPromotionTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordWithDefaultTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordWithPromotionTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.ResolvingRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateEncode
-
Setup the trial data.
- doSkipBytes(long) - Method in class org.apache.avro.io.BinaryDecoder
- Dot - Static variable in class org.apache.avro.idl.IdlLexer
- Dot - Static variable in class org.apache.avro.idl.IdlParser
- doTask(int, Object, ConcurrentReferenceHashMap.Task<T>) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Segment
-
Apply an update operation to this segment.
- Double - Static variable in class org.apache.avro.idl.IdlLexer
- Double - Static variable in class org.apache.avro.idl.IdlParser
- Double() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Double() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- DOUBLE - Enum constant in enum org.apache.avro.Schema.Type
- DOUBLE - Enum constant in enum org.apache.trevni.ValueType
- DOUBLE - Static variable in class org.apache.avro.io.parsing.Symbol
- DoubleArray(int, Schema) - Constructor for class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- DoubleArray(Schema, Collection<Double>) - Constructor for class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- 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
- DoubleTest - Class in org.apache.avro.perf.test.basic
- DoubleTest() - Constructor for class org.apache.avro.perf.test.basic.DoubleTest
- DoubleTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
- DoubleTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- DoubleTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType
- DoubleTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B1
- DoubleTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- DoubleTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B3
- DoubleTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType
- DoubleTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B1
- DoubleTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- DoubleTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B3
- DoubleTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType
- DoubleTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B1
- DoubleTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- DoubleTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- DoubleTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B3
- DoubleTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- DoubleTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- 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.
- DoubleWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.DoubleWritableConverter
-
Constructor.
- 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.
- duration() - Static method in class org.apache.avro.LogicalTypes
- DurationConversion() - Constructor for class org.apache.avro.Conversions.DurationConversion
E
- ELEMENT_PROP - Static variable in class org.apache.avro.specific.SpecificData
- elementAction - Variable in class org.apache.avro.Resolver.Container
- elementType - Variable in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- EmptyComment - Static variable in class org.apache.avro.idl.IdlLexer
- EmptyComment - Static variable in class org.apache.avro.idl.IdlParser
- enableDecimalLogicalType - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
Determines whether or not to use Java classes for decimal types
- encode(D) - Method in class org.apache.avro.message.BinaryMessageEncoder
- encode(D) - Method in interface org.apache.avro.message.MessageEncoder
-
Serialize a single datum to a ByteBuffer.
- encode(D) - Method in class org.apache.avro.message.RawMessageEncoder
- encode(D, OutputStream) - Method in class org.apache.avro.message.BinaryMessageEncoder
- encode(D, OutputStream) - Method in interface org.apache.avro.message.MessageEncoder
-
Serialize a single datum to an OutputStream.
- encode(D, OutputStream) - Method in class org.apache.avro.message.RawMessageEncoder
- encode(ChannelHandlerContext, NettyTransportCodec.NettyDataPack, List<Object>) - Method in class org.apache.avro.ipc.netty.NettyTransportCodec.NettyFrameEncoder
-
encode msg to ChannelBuffer
- 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(ArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.ArrayTest
- encode(BooleanTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.BooleanTest
- encode(BytesTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.BytesTest
- encode(DoubleTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.DoubleTest
- encode(ExtendedEnumTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest
- encode(FloatTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.FloatTest
- encode(IntTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.IntTest
- encode(LongTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.LongTest
- encode(MapTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.MapTest
- encode(SmallLongTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.SmallLongTest
- encode(StringTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.StringTest
- encode(UnchangedUnionTest.TestStateEncode) - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest
- encode(GenericNestedFakeTest.TestStateEncode) - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest
- encode(GenericNestedTest.TestStateEncode) - Method in class org.apache.avro.perf.test.generic.GenericNestedTest
- encode(GenericStringTest.TestStateEncode) - Method in class org.apache.avro.perf.test.generic.GenericStringTest
- encode(GenericTest.TestStateEncode) - Method in class org.apache.avro.perf.test.generic.GenericTest
- encode(GenericWithDefaultTest.TestStateEncode) - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest
- encode(ValidatingRecordTest.TestStateEncode) - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest
- encode(ReflectBigRecordTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest
- encode(ReflectDoubleArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest
- encode(ReflectFloatArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest
- encode(ReflectIntArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest
- encode(ReflectLargeFloatArrayBlockedTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest
- encode(ReflectLargeFloatArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest
- encode(ReflectLongArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest
- encode(ReflectNestedFloatArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest
- encode(ReflectNestedObjectArrayTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest
- encode(ReflectRecordTest.TestStateEncode) - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ArrayTest_TestStateEncode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BooleanTest_TestStateEncode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BytesTest_TestStateEncode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, DoubleTest_TestStateEncode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ExtendedEnumTest_TestStateEncode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, FloatTest_TestStateEncode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, IntTest_TestStateEncode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, LongTest_TestStateEncode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, MapTest_TestStateEncode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SmallLongTest_TestStateEncode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, StringTest_TestStateEncode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, UnchangedUnionTest_TestStateEncode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedFakeTest_TestStateEncode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedTest_TestStateEncode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericStringTest_TestStateEncode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericTest_TestStateEncode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithDefaultTest_TestStateEncode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ValidatingRecordTest_TestStateEncode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectBigRecordTest_TestStateEncode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectDoubleArrayTest_TestStateEncode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectFloatArrayTest_TestStateEncode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectIntArrayTest_TestStateEncode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayTest_TestStateEncode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLongArrayTest_TestStateEncode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedFloatArrayTest_TestStateEncode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedObjectArrayTest_TestStateEncode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectRecordTest_TestStateEncode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ArrayTest_TestStateEncode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, BooleanTest_TestStateEncode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, BytesTest_TestStateEncode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, DoubleTest_TestStateEncode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ExtendedEnumTest_TestStateEncode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, FloatTest_TestStateEncode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, IntTest_TestStateEncode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, LongTest_TestStateEncode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, MapTest_TestStateEncode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, SmallLongTest_TestStateEncode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, StringTest_TestStateEncode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, UnchangedUnionTest_TestStateEncode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericNestedFakeTest_TestStateEncode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericNestedTest_TestStateEncode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericStringTest_TestStateEncode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericTest_TestStateEncode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericWithDefaultTest_TestStateEncode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ValidatingRecordTest_TestStateEncode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectBigRecordTest_TestStateEncode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectDoubleArrayTest_TestStateEncode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectFloatArrayTest_TestStateEncode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectIntArrayTest_TestStateEncode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLargeFloatArrayTest_TestStateEncode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLongArrayTest_TestStateEncode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectNestedFloatArrayTest_TestStateEncode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectNestedObjectArrayTest_TestStateEncode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectRecordTest_TestStateEncode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ArrayTest_TestStateEncode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, BooleanTest_TestStateEncode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, BytesTest_TestStateEncode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, DoubleTest_TestStateEncode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ExtendedEnumTest_TestStateEncode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, FloatTest_TestStateEncode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, IntTest_TestStateEncode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, LongTest_TestStateEncode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, MapTest_TestStateEncode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, SmallLongTest_TestStateEncode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, StringTest_TestStateEncode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, UnchangedUnionTest_TestStateEncode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericNestedFakeTest_TestStateEncode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericNestedTest_TestStateEncode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericStringTest_TestStateEncode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericTest_TestStateEncode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericWithDefaultTest_TestStateEncode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ValidatingRecordTest_TestStateEncode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectBigRecordTest_TestStateEncode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectDoubleArrayTest_TestStateEncode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectFloatArrayTest_TestStateEncode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectIntArrayTest_TestStateEncode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLargeFloatArrayTest_TestStateEncode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLongArrayTest_TestStateEncode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectNestedFloatArrayTest_TestStateEncode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectNestedObjectArrayTest_TestStateEncode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectRecordTest_TestStateEncode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ArrayTest_TestStateEncode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BooleanTest_TestStateEncode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BytesTest_TestStateEncode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, DoubleTest_TestStateEncode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ExtendedEnumTest_TestStateEncode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, FloatTest_TestStateEncode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, IntTest_TestStateEncode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, LongTest_TestStateEncode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, MapTest_TestStateEncode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SmallLongTest_TestStateEncode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, StringTest_TestStateEncode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, UnchangedUnionTest_TestStateEncode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedFakeTest_TestStateEncode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedTest_TestStateEncode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericStringTest_TestStateEncode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericTest_TestStateEncode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithDefaultTest_TestStateEncode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ValidatingRecordTest_TestStateEncode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectBigRecordTest_TestStateEncode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectDoubleArrayTest_TestStateEncode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectFloatArrayTest_TestStateEncode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectIntArrayTest_TestStateEncode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayTest_TestStateEncode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLongArrayTest_TestStateEncode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedFloatArrayTest_TestStateEncode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedObjectArrayTest_TestStateEncode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- encode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectRecordTest_TestStateEncode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- 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
- 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
- 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
- enterArrayType(IdlParser.ArrayTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.arrayType()
. - enterArrayType(IdlParser.ArrayTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.arrayType()
. - enterEnumDeclaration(IdlParser.EnumDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.enumDeclaration()
. - enterEnumDeclaration(IdlParser.EnumDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.enumDeclaration()
. - enterEnumDefault(IdlParser.EnumDefaultContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.enumDefault()
. - enterEnumDefault(IdlParser.EnumDefaultContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.enumDefault()
. - enterEnumSymbol(IdlParser.EnumSymbolContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.enumSymbol()
. - enterEnumSymbol(IdlParser.EnumSymbolContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.enumSymbol()
. - enterEveryRule(ParserRuleContext) - Method in class org.apache.avro.idl.IdlBaseListener
- enterFieldDeclaration(IdlParser.FieldDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.fieldDeclaration()
. - enterFieldDeclaration(IdlParser.FieldDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.fieldDeclaration()
. - enterFixedDeclaration(IdlParser.FixedDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.fixedDeclaration()
. - enterFixedDeclaration(IdlParser.FixedDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.fixedDeclaration()
. - enterFormalParameter(IdlParser.FormalParameterContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.formalParameter()
. - enterFormalParameter(IdlParser.FormalParameterContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.formalParameter()
. - enterFullType(IdlParser.FullTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.fullType()
. - enterFullType(IdlParser.FullTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.fullType()
. - enterIdentifier(IdlParser.IdentifierContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.identifier()
. - enterIdentifier(IdlParser.IdentifierContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.identifier()
. - enterIdlFile(IdlParser.IdlFileContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.idlFile()
. - enterIdlFile(IdlParser.IdlFileContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.idlFile()
. - enterImportStatement(IdlParser.ImportStatementContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.importStatement()
. - enterImportStatement(IdlParser.ImportStatementContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.importStatement()
. - enterJsonArray(IdlParser.JsonArrayContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.jsonArray()
. - enterJsonArray(IdlParser.JsonArrayContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.jsonArray()
. - enterJsonLiteral(IdlParser.JsonLiteralContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.jsonLiteral()
. - enterJsonLiteral(IdlParser.JsonLiteralContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.jsonLiteral()
. - enterJsonObject(IdlParser.JsonObjectContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.jsonObject()
. - enterJsonObject(IdlParser.JsonObjectContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.jsonObject()
. - enterJsonPair(IdlParser.JsonPairContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.jsonPair()
. - enterJsonPair(IdlParser.JsonPairContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.jsonPair()
. - enterJsonValue(IdlParser.JsonValueContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.jsonValue()
. - enterJsonValue(IdlParser.JsonValueContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.jsonValue()
. - enterMainSchemaDeclaration(IdlParser.MainSchemaDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.mainSchemaDeclaration()
. - enterMainSchemaDeclaration(IdlParser.MainSchemaDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.mainSchemaDeclaration()
. - enterMapType(IdlParser.MapTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.mapType()
. - enterMapType(IdlParser.MapTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.mapType()
. - enterMessageDeclaration(IdlParser.MessageDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.messageDeclaration()
. - enterMessageDeclaration(IdlParser.MessageDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.messageDeclaration()
. - enterNamedSchemaDeclaration(IdlParser.NamedSchemaDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.namedSchemaDeclaration()
. - enterNamedSchemaDeclaration(IdlParser.NamedSchemaDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.namedSchemaDeclaration()
. - enterNamespaceDeclaration(IdlParser.NamespaceDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.namespaceDeclaration()
. - enterNamespaceDeclaration(IdlParser.NamespaceDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.namespaceDeclaration()
. - enterNullableType(IdlParser.NullableTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.nullableType()
. - enterNullableType(IdlParser.NullableTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.nullableType()
. - enterPlainType(IdlParser.PlainTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.plainType()
. - enterPlainType(IdlParser.PlainTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.plainType()
. - enterPrimitiveType(IdlParser.PrimitiveTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.primitiveType()
. - enterPrimitiveType(IdlParser.PrimitiveTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.primitiveType()
. - enterProtocolDeclaration(IdlParser.ProtocolDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.protocolDeclaration()
. - enterProtocolDeclaration(IdlParser.ProtocolDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.protocolDeclaration()
. - enterProtocolDeclarationBody(IdlParser.ProtocolDeclarationBodyContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.protocolDeclarationBody()
. - enterProtocolDeclarationBody(IdlParser.ProtocolDeclarationBodyContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.protocolDeclarationBody()
. - enterRecordBody(IdlParser.RecordBodyContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.recordBody()
. - enterRecordBody(IdlParser.RecordBodyContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.recordBody()
. - enterRecordDeclaration(IdlParser.RecordDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.recordDeclaration()
. - enterRecordDeclaration(IdlParser.RecordDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.recordDeclaration()
. - enterResultType(IdlParser.ResultTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.resultType()
. - enterResultType(IdlParser.ResultTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.resultType()
. - enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.EnumDefaultContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FormalParameterContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FullTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonPairContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonValueContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.MapTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.NamedSchemaDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.NullableTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.PlainTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.RecordBodyContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ResultTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- enterRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- enterSchemaProperty(IdlParser.SchemaPropertyContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.schemaProperty()
. - enterSchemaProperty(IdlParser.SchemaPropertyContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.schemaProperty()
. - enterUnionType(IdlParser.UnionTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.unionType()
. - enterUnionType(IdlParser.UnionTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.unionType()
. - enterVariableDeclaration(IdlParser.VariableDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Enter a parse tree produced by
IdlParser.variableDeclaration()
. - enterVariableDeclaration(IdlParser.VariableDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Enter a parse tree produced by
IdlParser.variableDeclaration()
. - Entry(K, V) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Entry
- entrySet() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- entrySet() - Method in class org.apache.avro.util.WeakIdentityHashMap
- Enum - Static variable in class org.apache.avro.idl.IdlLexer
- Enum - Static variable in class org.apache.avro.idl.IdlParser
- Enum() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- Enum() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- ENUM - Enum constant in enum org.apache.avro.Resolver.Action.Type
- ENUM - Enum constant in enum org.apache.avro.Schema.Type
- ENUM - Static variable in class org.apache.avro.io.parsing.Symbol
- enumAdjustAction(int, Object[]) - Static method in class org.apache.avro.io.parsing.Symbol
- EnumAdjustAction(int, Object[]) - Constructor for class org.apache.avro.io.parsing.Symbol.EnumAdjustAction
-
Deprecated.
- enumDeclaration() - Method in class org.apache.avro.idl.IdlParser
- enumDeclaration() - Method in class org.apache.avro.idl.IdlParser.NamedSchemaDeclarationContext
- EnumDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- enumDefault() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- enumDefault() - Method in class org.apache.avro.idl.IdlParser
- enumDefault(String) - Method in class org.apache.avro.SchemaBuilder.EnumDefault
-
Completes this field with the default value provided, cannot be null
- EnumDefaultContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.EnumDefaultContext
- 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.
- EnumLabelsAction(List<String>) - Constructor for class org.apache.avro.io.parsing.Symbol.EnumLabelsAction
-
Deprecated.
- enumSymbol - Variable in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- enumSymbol() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- enumSymbol() - Method in class org.apache.avro.idl.IdlParser
- enumSymbol(int) - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- EnumSymbol(Schema, Object) - Constructor for class org.apache.avro.generic.GenericData.EnumSymbol
-
Maps existing Objects into an Avro enum by calling toString(), eg for Java Enums
- EnumSymbol(Schema, String) - Constructor for class org.apache.avro.generic.GenericData.EnumSymbol
- EnumSymbolContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.EnumSymbolContext
- enumSymbols - Variable in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- EOF() - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- 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.DeflateCodec
- equals(Object) - Method in class org.apache.avro.file.SnappyCodec
- equals(Object) - Method in class org.apache.avro.file.XZCodec
- equals(Object) - Method in class org.apache.avro.file.ZstandardCodec
- equals(Object) - Method in class org.apache.avro.generic.GenericData.AbstractArray
- 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.LogicalTypes.Decimal
- 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.Schema.SeenPair
- equals(Object) - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
- equals(Object) - Method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
- equals(Object) - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
- equals(Object) - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- equals(Object) - Method in class org.apache.avro.specific.SpecificFixed
- equals(Object) - Method in class org.apache.avro.specific.SpecificRecordBase
- equals(Object) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Entry
- equals(Object) - Method in class org.apache.avro.util.TimePeriod
- equals(Object) - Method in class org.apache.avro.util.Utf8
- equals(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
- Equals - Static variable in class org.apache.avro.idl.IdlLexer
- Equals - Static variable in class org.apache.avro.idl.IdlParser
- Equals() - Method in class org.apache.avro.idl.IdlParser.EnumDefaultContext
- Equals() - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- error - Variable in class org.apache.avro.ipc.RPCContext
- error - Variable in class org.apache.avro.Resolver.ErrorAction
- error() - Method in class org.apache.avro.ipc.RPCContext
-
The exception generated at the server, or null if no such exception has occurred
- Error - Static variable in class org.apache.avro.idl.IdlLexer
- Error - Static variable in class org.apache.avro.idl.IdlParser
- Error() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Error() - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- ERROR - Enum constant in enum org.apache.avro.Resolver.Action.Type
- ERROR_RESERVED_WORDS - Static variable in class org.apache.avro.specific.SpecificData
- ErrorAction(Schema, Schema, GenericData, Resolver.ErrorAction.ErrorType) - Constructor for class org.apache.avro.Resolver.ErrorAction
- ErrorBuilder<T> - Interface in org.apache.avro.data
-
Interface for error builders
- errors - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- 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
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.avro.ipc.netty.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.avro_maven_plugin.HelpMojo
- 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.InduceMojo
- execute(Object, Decoder) - Method in interface org.apache.avro.io.FastReaderBuilder.ExecutionStep
- exitArrayType(IdlParser.ArrayTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.arrayType()
. - exitArrayType(IdlParser.ArrayTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.arrayType()
. - exitEnumDeclaration(IdlParser.EnumDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.enumDeclaration()
. - exitEnumDeclaration(IdlParser.EnumDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.enumDeclaration()
. - exitEnumDefault(IdlParser.EnumDefaultContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.enumDefault()
. - exitEnumDefault(IdlParser.EnumDefaultContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.enumDefault()
. - exitEnumSymbol(IdlParser.EnumSymbolContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.enumSymbol()
. - exitEnumSymbol(IdlParser.EnumSymbolContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.enumSymbol()
. - exitEveryRule(ParserRuleContext) - Method in class org.apache.avro.idl.IdlBaseListener
- exitFieldDeclaration(IdlParser.FieldDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.fieldDeclaration()
. - exitFieldDeclaration(IdlParser.FieldDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.fieldDeclaration()
. - exitFixedDeclaration(IdlParser.FixedDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.fixedDeclaration()
. - exitFixedDeclaration(IdlParser.FixedDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.fixedDeclaration()
. - exitFormalParameter(IdlParser.FormalParameterContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.formalParameter()
. - exitFormalParameter(IdlParser.FormalParameterContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.formalParameter()
. - exitFullType(IdlParser.FullTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.fullType()
. - exitFullType(IdlParser.FullTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.fullType()
. - exitIdentifier(IdlParser.IdentifierContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.identifier()
. - exitIdentifier(IdlParser.IdentifierContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.identifier()
. - exitIdlFile(IdlParser.IdlFileContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.idlFile()
. - exitIdlFile(IdlParser.IdlFileContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.idlFile()
. - exitImportStatement(IdlParser.ImportStatementContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.importStatement()
. - exitImportStatement(IdlParser.ImportStatementContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.importStatement()
. - exitJsonArray(IdlParser.JsonArrayContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.jsonArray()
. - exitJsonArray(IdlParser.JsonArrayContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.jsonArray()
. - exitJsonLiteral(IdlParser.JsonLiteralContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.jsonLiteral()
. - exitJsonLiteral(IdlParser.JsonLiteralContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.jsonLiteral()
. - exitJsonObject(IdlParser.JsonObjectContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.jsonObject()
. - exitJsonObject(IdlParser.JsonObjectContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.jsonObject()
. - exitJsonPair(IdlParser.JsonPairContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.jsonPair()
. - exitJsonPair(IdlParser.JsonPairContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.jsonPair()
. - exitJsonValue(IdlParser.JsonValueContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.jsonValue()
. - exitJsonValue(IdlParser.JsonValueContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.jsonValue()
. - exitMainSchemaDeclaration(IdlParser.MainSchemaDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.mainSchemaDeclaration()
. - exitMainSchemaDeclaration(IdlParser.MainSchemaDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.mainSchemaDeclaration()
. - exitMapType(IdlParser.MapTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.mapType()
. - exitMapType(IdlParser.MapTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.mapType()
. - exitMessageDeclaration(IdlParser.MessageDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.messageDeclaration()
. - exitMessageDeclaration(IdlParser.MessageDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.messageDeclaration()
. - exitNamedSchemaDeclaration(IdlParser.NamedSchemaDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.namedSchemaDeclaration()
. - exitNamedSchemaDeclaration(IdlParser.NamedSchemaDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.namedSchemaDeclaration()
. - exitNamespaceDeclaration(IdlParser.NamespaceDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.namespaceDeclaration()
. - exitNamespaceDeclaration(IdlParser.NamespaceDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.namespaceDeclaration()
. - exitNullableType(IdlParser.NullableTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.nullableType()
. - exitNullableType(IdlParser.NullableTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.nullableType()
. - exitPlainType(IdlParser.PlainTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.plainType()
. - exitPlainType(IdlParser.PlainTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.plainType()
. - exitPrimitiveType(IdlParser.PrimitiveTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.primitiveType()
. - exitPrimitiveType(IdlParser.PrimitiveTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.primitiveType()
. - exitProtocolDeclaration(IdlParser.ProtocolDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.protocolDeclaration()
. - exitProtocolDeclaration(IdlParser.ProtocolDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.protocolDeclaration()
. - exitProtocolDeclarationBody(IdlParser.ProtocolDeclarationBodyContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.protocolDeclarationBody()
. - exitProtocolDeclarationBody(IdlParser.ProtocolDeclarationBodyContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.protocolDeclarationBody()
. - exitRecordBody(IdlParser.RecordBodyContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.recordBody()
. - exitRecordBody(IdlParser.RecordBodyContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.recordBody()
. - exitRecordDeclaration(IdlParser.RecordDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.recordDeclaration()
. - exitRecordDeclaration(IdlParser.RecordDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.recordDeclaration()
. - exitResultType(IdlParser.ResultTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.resultType()
. - exitResultType(IdlParser.ResultTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.resultType()
. - exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.EnumDefaultContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FormalParameterContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.FullTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonPairContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.JsonValueContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.MapTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.NamedSchemaDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.NullableTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.PlainTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.RecordBodyContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.ResultTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- exitRule(ParseTreeListener) - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- exitSchemaProperty(IdlParser.SchemaPropertyContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.schemaProperty()
. - exitSchemaProperty(IdlParser.SchemaPropertyContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.schemaProperty()
. - exitUnionType(IdlParser.UnionTypeContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.unionType()
. - exitUnionType(IdlParser.UnionTypeContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.unionType()
. - exitVariableDeclaration(IdlParser.VariableDeclarationContext) - Method in class org.apache.avro.idl.IdlBaseListener
-
Exit a parse tree produced by
IdlParser.variableDeclaration()
. - exitVariableDeclaration(IdlParser.VariableDeclarationContext) - Method in interface org.apache.avro.idl.IdlListener
-
Exit a parse tree produced by
IdlParser.variableDeclaration()
. - EXPLICIT_ACTION - Enum constant in enum org.apache.avro.io.parsing.Symbol.Kind
-
non-terminal action symbol which is explicitly consumed
- Explicit Types and Types by Name - Search tag in class org.apache.avro.SchemaBuilder
- Section
- 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
- ExtendedEnumTest - Class in org.apache.avro.perf.test.basic
- ExtendedEnumTest() - Constructor for class org.apache.avro.perf.test.basic.ExtendedEnumTest
- ExtendedEnumTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
- ExtendedEnumTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_encode_jmhTest
- ExtendedEnumTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType
- ExtendedEnumTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B1
- ExtendedEnumTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- ExtendedEnumTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B3
- ExtendedEnumTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType
- ExtendedEnumTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B1
- ExtendedEnumTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- ExtendedEnumTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B3
- ExtendedEnumTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType
- ExtendedEnumTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B1
- ExtendedEnumTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- ExtendedEnumTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- ExtendedEnumTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B3
- ExtendedEnumTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- ExtendedEnumTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
F
- f1 - Variable in class org.apache.avro.perf.test.BasicRecord
- f2 - Variable in class org.apache.avro.perf.test.BasicRecord
- f2 - Variable in class org.apache.avro.perf.test.BigRecord
- f22 - Variable in class org.apache.avro.perf.test.BigRecord
- f3 - Variable in class org.apache.avro.perf.test.BasicRecord
- f3 - Variable in class org.apache.avro.perf.test.BigRecord
- f33 - Variable in class org.apache.avro.perf.test.BigRecord
- f4 - Variable in class org.apache.avro.perf.test.BasicRecord
- f4 - Variable in class org.apache.avro.perf.test.BigRecord
- f44 - Variable in class org.apache.avro.perf.test.BigRecord
- f5 - Variable in class org.apache.avro.perf.test.BasicRecord
- f5 - Variable in class org.apache.avro.perf.test.BigRecord
- f55 - Variable in class org.apache.avro.perf.test.BigRecord
- f6 - Variable in class org.apache.avro.perf.test.BasicRecord
- f6 - Variable in class org.apache.avro.perf.test.BigRecord
- f66 - Variable in class org.apache.avro.perf.test.BigRecord
- fail(String) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Called by a failing task to abort.
- FAST_READER_PROP - Static variable in class org.apache.avro.generic.GenericData
- FastReaderBuilder - Class in org.apache.avro.io
- FastReaderBuilder(GenericData) - Constructor for class org.apache.avro.io.FastReaderBuilder
- FastReaderBuilder.ExecutionStep - Interface in org.apache.avro.io
- FastReaderBuilder.FieldReader - Interface in org.apache.avro.io
- FastReaderBuilder.MapReader - Class in org.apache.avro.io
- FastReaderBuilder.RecordReader - Class in org.apache.avro.io
- FastReaderBuilder.RecordReader.Stage - Enum in org.apache.avro.io
- FastReaderBuilder.ReusingFieldReader - Interface in org.apache.avro.io
- Field(String, Schema) - Constructor for class org.apache.avro.Schema.Field
- Field(String, Schema, String) - Constructor for class org.apache.avro.Schema.Field
- Field(String, Schema, String, Object) - Constructor for class org.apache.avro.Schema.Field
- Field(String, Schema, String, Object, Schema.Field.Order) - Constructor for class org.apache.avro.Schema.Field
- Field(Schema.Field, Schema) - Constructor for class org.apache.avro.Schema.Field
-
Constructs a new Field instance with the same
name
,doc
,defaultValue
, andorder
asfield
has with changing the schema to the specified one. - FIELD_ACTION - Static variable in class org.apache.avro.io.parsing.Symbol
- FIELD_END - Static variable in class org.apache.avro.io.parsing.Symbol
- fieldActions - Variable in class org.apache.avro.Resolver.RecordAdjust
-
An action for each field of the writer.
- fieldAdjustAction(int, String, Set<String>) - Static method in class org.apache.avro.io.parsing.Symbol
- FieldAdjustAction(int, String, Set<String>) - Constructor for class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
-
Deprecated.
- fieldDeclaration - Variable in class org.apache.avro.idl.IdlParser.RecordBodyContext
- fieldDeclaration() - Method in class org.apache.avro.idl.IdlParser
- fieldDeclaration() - Method in class org.apache.avro.idl.IdlParser.RecordBodyContext
- fieldDeclaration(int) - Method in class org.apache.avro.idl.IdlParser.RecordBodyContext
- FieldDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- fieldName - Variable in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- fieldOrderAction(Schema.Field[]) - Static method in class org.apache.avro.io.parsing.Symbol
- FieldOrderAction(Schema.Field[]) - Constructor for class org.apache.avro.io.parsing.Symbol.FieldOrderAction
-
Deprecated.
- fields - Variable in class org.apache.avro.idl.IdlParser.RecordBodyContext
- fields - Variable in class org.apache.avro.io.parsing.Symbol.FieldOrderAction
- fields() - Method in class org.apache.avro.data.RecordBuilderBase
- fields() - Method in class org.apache.avro.SchemaBuilder.RecordBuilder
- Fields - Search tag in class org.apache.avro.SchemaBuilder
- Section
- fieldSetFlags() - Method in class org.apache.avro.data.RecordBuilderBase
- fieldType - Variable in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- FileReader<D> - Interface in org.apache.avro.file
-
Interface for reading data from a file.
- find(String, String) - Method in class org.apache.avro.ParseContext
-
Find a schema by name and namespace.
- findByFingerprint(long) - Method in class org.apache.avro.message.SchemaStore.Cache
- findByFingerprint(long) - Method in interface org.apache.avro.message.SchemaStore
-
Retrieves a fingerprint by its AVRO-CRC-64 fingerprint.
- findClasspath() - Method in class org.apache.avro.mojo.AbstractAvroMojo
- 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.
- fingerprint64(Schema) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for use by templates.
- finishInitialization(FastReaderBuilder.ExecutionStep[], Schema, GenericData.InstanceSupplier) - Method in class org.apache.avro.io.FastReaderBuilder.RecordReader
- firstDefault - Variable in class org.apache.avro.Resolver.RecordAdjust
-
Pointer into
Resolver.RecordAdjust.readerOrder
of the first reader field whose value comes from a default value. - firstMatch - Variable in class org.apache.avro.Resolver.ReaderUnion
- 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.
- Fixed - Static variable in class org.apache.avro.idl.IdlLexer
- Fixed - Static variable in class org.apache.avro.idl.IdlParser
- Fixed() - Constructor for class org.apache.avro.generic.GenericData.Fixed
- Fixed(Schema) - Constructor for class org.apache.avro.generic.GenericData.Fixed
- Fixed(Schema, byte[]) - Constructor for class org.apache.avro.generic.GenericData.Fixed
- Fixed() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- Fixed() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- FIXED - Enum constant in enum org.apache.avro.Schema.Type
- FIXED - Static variable in class org.apache.avro.io.parsing.Symbol
- FIXED_SIZE_MISMATCH - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaIncompatibilityType
- FIXED32 - Enum constant in enum org.apache.trevni.ValueType
- FIXED64 - Enum constant in enum org.apache.trevni.ValueType
- fixedDeclaration() - Method in class org.apache.avro.idl.IdlParser
- fixedDeclaration() - Method in class org.apache.avro.idl.IdlParser.NamedSchemaDeclarationContext
- FixedDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- fixedDefault(byte[]) - 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.
- fixedDefault(ByteBuffer) - 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() - Method in class org.apache.avro.io.parsing.Symbol.Sequence
- 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.
- Float - Static variable in class org.apache.avro.idl.IdlLexer
- Float - Static variable in class org.apache.avro.idl.IdlParser
- Float() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Float() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- FLOAT - Enum constant in enum org.apache.avro.Schema.Type
- FLOAT - Enum constant in enum org.apache.trevni.ValueType
- FLOAT - Static variable in class org.apache.avro.io.parsing.Symbol
- FloatArray(int, Schema) - Constructor for class org.apache.avro.generic.PrimitivesArrays.FloatArray
- FloatArray(Schema, Collection<Float>) - Constructor for class org.apache.avro.generic.PrimitivesArrays.FloatArray
- 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
- FloatingPointLiteral - Static variable in class org.apache.avro.idl.IdlLexer
- FloatingPointLiteral - Static variable in class org.apache.avro.idl.IdlParser
- FloatingPointLiteral() - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- FloatTest - Class in org.apache.avro.perf.test.basic
- FloatTest() - Constructor for class org.apache.avro.perf.test.basic.FloatTest
- FloatTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
- FloatTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
- FloatTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType
- FloatTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B1
- FloatTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- FloatTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B3
- FloatTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType
- FloatTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B1
- FloatTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- FloatTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B3
- FloatTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType
- FloatTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B1
- FloatTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- FloatTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- FloatTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B3
- FloatTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- FloatTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- 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.
- FloatWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.FloatWritableConverter
-
Constructor.
- 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.grpc.AvroInputStream.CountingOutputStream
- 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
- forEachProperty(BiConsumer<String, Object>) - Method in class org.apache.avro.JsonProperties
- formalParameter - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- formalParameter() - Method in class org.apache.avro.idl.IdlParser
- formalParameter() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- formalParameter(int) - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- FormalParameterContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.FormalParameterContext
- formalParameters - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- format(String, Schema) - Static method in interface org.apache.avro.SchemaFormatter
-
Format a schema with the specified format.
- format(Schema) - Method in class org.apache.avro.CanonicalSchemaFormatterFactory
- format(Schema) - Method in class org.apache.avro.idl.IdlSchemaFormatter
- format(Schema) - Method in class org.apache.avro.JsonSchemaFormatter
- format(Schema) - Method in interface org.apache.avro.SchemaFormatter
-
Write the specified schema as a String.
- formatName() - Method in interface org.apache.avro.SchemaFormatterFactory
-
Return the name of the format this formatter factory supports.
- FormattedSchemaParser - Interface in org.apache.avro
-
Schema parser for a specific schema format.
- forName(Class<?>, String) - Static method in class org.apache.avro.util.ClassUtils
-
Loads a class using the class loader. 1.
- forName(ClassLoader, String) - Static method in class org.apache.avro.util.ClassUtils
-
Loads a class using the class loader. 1.
- forName(String) - Static method in class org.apache.avro.util.ClassUtils
-
Loads a class using the class loader. 1.
- forName(String) - Static method in enum org.apache.trevni.ValueType
-
Return a type given its name.
- from(TemporalAmount) - Static method in class org.apache.avro.util.TimePeriod
- fromArray(Collection<?>, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromBoolean(Boolean, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromByteBuffer(ByteBuffer) - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Deserializes a HandshakeRequest from a ByteBuffer.
- fromByteBuffer(ByteBuffer) - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Deserializes a HandshakeResponse from a ByteBuffer.
- fromBytes(ByteBuffer, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromBytes(ByteBuffer, Schema, LogicalType) - Method in class org.apache.avro.Conversions.BigDecimalConversion
- fromBytes(ByteBuffer, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DecimalConversion
- fromCharSequence(CharSequence, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromCharSequence(CharSequence, Schema, LogicalType) - Method in class org.apache.avro.Conversions.UUIDConversion
- fromDouble(Double, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromEnumSymbol(GenericEnumSymbol<?>, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromFixed(GenericFixed, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromFixed(GenericFixed, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DecimalConversion
- fromFixed(GenericFixed, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DurationConversion
- fromFixed(GenericFixed, Schema, LogicalType) - Method in class org.apache.avro.Conversions.UUIDConversion
- fromFloat(Float, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromHadoopString(String) - Static method in class org.apache.avro.hadoop.file.HadoopCodecFactory
-
Maps a hadoop codec name into a CodecFactory.
- fromInt(Integer, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromInt(Integer, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.DateConversion
- fromInt(Integer, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimeMillisConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMicrosConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMillisConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampNanosConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimeMicrosConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampMillisConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampNanosConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMicrosConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampNanosConversion
- fromMap(Map<?, ?>, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromRecord(IndexedRecord, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- fromSchema(Schema) - Static method in class org.apache.avro.LogicalTypes
-
Returns the
LogicalType
from the schema, if one is present. - fromSchema(Schema) - Method in interface org.apache.avro.LogicalTypes.LogicalTypeFactory
- fromSchemaIgnoreInvalid(Schema) - Static method in class org.apache.avro.LogicalTypes
- 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
-
Adapt an
FSDataInputStream
toSeekableInput
. - FsInput(Path, Configuration) - Constructor for class org.apache.avro.mapred.FsInput
-
Construct given a path and a configuration.
- FsInput(Path, FileSystem) - Constructor for class org.apache.avro.mapred.FsInput
-
Construct given a path and a
FileSystem
. - fSync() - Method in class org.apache.avro.file.DataFileWriter
-
If this writer was instantiated using a File, FileOutputStream or Syncable instance, this method flushes all buffers for this writer to disk.
- fullType - Variable in class org.apache.avro.idl.IdlParser.UnionTypeContext
- fullType() - Method in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- fullType() - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- fullType() - Method in class org.apache.avro.idl.IdlParser.FormalParameterContext
- fullType() - Method in class org.apache.avro.idl.IdlParser
- fullType() - Method in class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- fullType() - Method in class org.apache.avro.idl.IdlParser.MapTypeContext
- fullType() - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- fullType(int) - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- FullTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.FullTypeContext
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) - 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.JsonGrammarGenerator
-
Returns the non-terminal that is the start symbol for grammar of 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.
- 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.
- generateClearMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field "clear" method.
- generateGetBuilderMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field Builder accessor method.
- generateGetMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field accessor method.
- generateGetOptionalMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field accessor method that returns a Java 8 Optional.
- generateHasBuilderMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field Builder "has" method.
- generateHasMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field "has" method.
- generateSetBuilderMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field Builder mutator method.
- generateSetMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field mutator method.
- generateSetterCode(Schema, String, String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- 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.AbstractArray<T> - Class in org.apache.avro.generic
- GenericData.Array<T> - Class in org.apache.avro.generic
-
Default implementation of an array.
- GenericData.EnumSymbol - Class in org.apache.avro.generic
-
Default implementation of
GenericEnumSymbol
. - GenericData.Fixed - Class in org.apache.avro.generic
-
Default implementation of
GenericFixed
. - GenericData.InstanceSupplier - Interface in org.apache.avro.generic
- GenericData.Record - Class in org.apache.avro.generic
-
Default implementation of
GenericRecord
. - 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(GenericData) - 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
- 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<E> - Interface in org.apache.avro.generic
-
An enum symbol.
- GenericFixed - Interface in org.apache.avro.generic
-
Fixed-size data.
- GenericNestedFakeTest - Class in org.apache.avro.perf.test.generic
- GenericNestedFakeTest() - Constructor for class org.apache.avro.perf.test.generic.GenericNestedFakeTest
- GenericNestedFakeTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
- GenericNestedFakeTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_encode_jmhTest
- GenericNestedFakeTest_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType
- GenericNestedFakeTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B1
- GenericNestedFakeTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- GenericNestedFakeTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B3
- GenericNestedFakeTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType
- GenericNestedFakeTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B1
- GenericNestedFakeTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- GenericNestedFakeTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B3
- GenericNestedFakeTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType
- GenericNestedFakeTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B1
- GenericNestedFakeTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- GenericNestedFakeTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedFakeTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B3
- GenericNestedFakeTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
- GenericNestedFakeTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
- GenericNestedTest - Class in org.apache.avro.perf.test.generic
- GenericNestedTest() - Constructor for class org.apache.avro.perf.test.generic.GenericNestedTest
- GenericNestedTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
- GenericNestedTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_encode_jmhTest
- GenericNestedTest_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType
- GenericNestedTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B1
- GenericNestedTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- GenericNestedTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B3
- GenericNestedTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType
- GenericNestedTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B1
- GenericNestedTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- GenericNestedTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B3
- GenericNestedTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType
- GenericNestedTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B1
- GenericNestedTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- GenericNestedTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericNestedTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B3
- GenericNestedTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
- GenericNestedTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
- 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(GenericData.Record) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
-
Creates a GenericRecordBuilder by copying an existing record instance.
- GenericRecordBuilder(GenericRecordBuilder) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
-
Creates a GenericRecordBuilder by copying an existing GenericRecordBuilder.
- GenericRecordBuilder(Schema) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
-
Creates a GenericRecordBuilder for building Record instances.
- 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
- GenericStringTest - Class in org.apache.avro.perf.test.generic
- GenericStringTest() - Constructor for class org.apache.avro.perf.test.generic.GenericStringTest
- GenericStringTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
- GenericStringTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_encode_jmhTest
- GenericStringTest_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType
- GenericStringTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B1
- GenericStringTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- GenericStringTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B3
- GenericStringTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType
- GenericStringTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B1
- GenericStringTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- GenericStringTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B3
- GenericStringTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType
- GenericStringTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B1
- GenericStringTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- GenericStringTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericStringTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B3
- GenericStringTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
- GenericStringTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
- GenericTest - Class in org.apache.avro.perf.test.generic
- GenericTest() - Constructor for class org.apache.avro.perf.test.generic.GenericTest
- GenericTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
- GenericTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_encode_jmhTest
- GenericTest_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType
- GenericTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B1
- GenericTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- GenericTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B3
- GenericTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType
- GenericTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B1
- GenericTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- GenericTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B3
- GenericTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType
- GenericTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B1
- GenericTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- GenericTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B3
- GenericTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
- GenericTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
- GenericWithDefaultTest - Class in org.apache.avro.perf.test.generic
- GenericWithDefaultTest() - Constructor for class org.apache.avro.perf.test.generic.GenericWithDefaultTest
- GenericWithDefaultTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
- GenericWithDefaultTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_encode_jmhTest
- GenericWithDefaultTest_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType
- GenericWithDefaultTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B1
- GenericWithDefaultTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- GenericWithDefaultTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B3
- GenericWithDefaultTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType
- GenericWithDefaultTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B1
- GenericWithDefaultTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- GenericWithDefaultTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B3
- GenericWithDefaultTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType
- GenericWithDefaultTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B1
- GenericWithDefaultTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- GenericWithDefaultTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithDefaultTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B3
- GenericWithDefaultTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
- GenericWithDefaultTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
- GenericWithOutOfOrderTest - Class in org.apache.avro.perf.test.generic
- GenericWithOutOfOrderTest() - Constructor for class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest
- GenericWithOutOfOrderTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
- GenericWithOutOfOrderTest_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType
- GenericWithOutOfOrderTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B1
- GenericWithOutOfOrderTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- GenericWithOutOfOrderTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B3
- GenericWithOutOfOrderTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B1
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B3
- GenericWithOutOfOrderTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
- GenericWithPromotionTest - Class in org.apache.avro.perf.test.generic
- GenericWithPromotionTest() - Constructor for class org.apache.avro.perf.test.generic.GenericWithPromotionTest
- GenericWithPromotionTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
- GenericWithPromotionTest_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType
- GenericWithPromotionTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B1
- GenericWithPromotionTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- GenericWithPromotionTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B3
- GenericWithPromotionTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType
- GenericWithPromotionTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B1
- GenericWithPromotionTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- GenericWithPromotionTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.jmh_generated
- GenericWithPromotionTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B3
- GenericWithPromotionTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
- get() - Method in class org.apache.avro.compiler.schema.CloningVisitor
- get() - Method in interface org.apache.avro.compiler.schema.SchemaVisitor
-
Invoked when visiting is complete.
- get() - Static method in class org.apache.avro.generic.GenericData
-
Return the singleton instance.
- 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() - Static method in class org.apache.avro.io.FastReaderBuilder
- get() - Method in class org.apache.avro.ipc.CallFuture
- 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() - Static method in class org.apache.avro.thrift.ThriftData
-
Return the singleton instance.
- get() - Method in class org.apache.avro.util.SchemaResolver.IsResolvedSchemaVisitor
- get() - Method in class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- get() - Method in interface org.apache.avro.util.SchemaVisitor
-
Invoked when visiting is complete.
- get() - Method in interface org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Reference
-
Return the referenced entry, or
null
if the entry is no longer available. - get(int) - Method in class org.apache.avro.generic.GenericData.Array
- get(int) - Method in class org.apache.avro.generic.GenericData.Record
- 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(int) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- get(int) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- get(int) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- get(int) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- get(int) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- get(int) - Method in class org.apache.avro.io.parsing.Symbol.Sequence
- 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.mapred.Pair
- get(int) - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- get(long, TimeUnit) - Method in class org.apache.avro.ipc.CallFuture
- get(Object) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- get(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
- get(String) - 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(String) - Method in class org.apache.avro.specific.SpecificRecordBase
- get(TemporalUnit) - Method in class org.apache.avro.util.TimePeriod
- 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(Schema.Field) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Gets the value of a field.
- get(MetaData) - Static method in class org.apache.trevni.BZip2Codec
- getAliases() - Method in class org.apache.avro.Schema
-
If this is a record, enum or fixed, return its aliases, if any.
- getArrayAsCollection(Object) - Method in class org.apache.avro.generic.GenericData
-
Called to access an array as a collection.
- getArrayAsCollection(Object) - Method in class org.apache.avro.reflect.ReflectData
- 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() - Method in class org.apache.avro.perf.test.BasicArrayState
- 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. - getATN() - Method in class org.apache.avro.idl.IdlLexer
- getATN() - Method in class org.apache.avro.idl.IdlParser
- 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.
- getBatchSize() - Method in class org.apache.avro.perf.test.BasicArrayState
- getBatchSize() - Method in class org.apache.avro.perf.test.BasicState
- 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.file.DataFileStream
-
Expert: Return the size in bytes (uncompressed) of 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(int) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
-
Direct primitive int access.
- 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 exception class org.apache.avro.path.TracingClassCastException
- getCause() - Method in exception class org.apache.avro.path.TracingNullPointException
- getCause() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
- getChannelNames() - Method in class org.apache.avro.idl.IdlLexer
- 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.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 enum org.apache.avro.mapred.tether.TaskType
- 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>, SpecificRequestor) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Create a proxy instance whose methods invoke RPCs.
- 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) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
-
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>, Transceiver, SpecificData) - 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.avro.hadoop.file.SortedKeyValueFile.Writer.Options
-
Return the compression codec.
- getCodec() - Method in class org.apache.trevni.MetaData
-
Return the compression codec name.
- getCollector(String, String, Reporter) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
-
Gets the output collector for a named output.
- getCollector(String, Reporter) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
-
Deprecated.Use
AvroMultipleOutputs.collect(java.lang.String, org.apache.hadoop.mapred.Reporter, java.lang.Object)
method for collecting output - 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.
- getCompatibility() - Method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
-
Returns the SchemaCompatibilityType, always non-null.
- getCompressionCodec() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Gets the compression codec.
- getCompressionCodec(TaskAttemptContext) - Static method in class org.apache.avro.mapreduce.AvroOutputFormatBase
-
Gets the configured compression codec from the task context.
- getCompressionType() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Gets the type of compression.
- getConfiguration() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
-
Gets the configuration.
- getConfiguration() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
-
Gets the configuration.
- getConfiguration() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
-
Gets the Hadoop configuration.
- getConfiguration() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Gets the Hadoop configuration.
- getConfigurationWithAvroSerialization() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
-
Gets the Hadoop configuration with Avro serialization registered.
- getConfigurationWithAvroSerialization() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Gets the Hadoop configuration with Avro serialization registered.
- getConfiguredBufferSize() - Method in class org.apache.avro.io.DecoderFactory
-
Returns this factory's configured preferred buffer size.
- getConstructorAsFunction(Class<V>, Class<R>) - Static method in class org.apache.avro.reflect.ReflectionUtil
- getConversion(int) - Method in class org.apache.avro.specific.SpecificRecordBase
- getConversion(String) - Method in class org.apache.avro.specific.SpecificRecordBase
- getConversionByClass(Class<T>) - Method in class org.apache.avro.generic.GenericData
-
Returns the first conversion found for the given class.
- getConversionByClass(Class<T>, LogicalType) - Method in class org.apache.avro.generic.GenericData
-
Returns the conversion for the given class and logical type.
- getConversionFor(LogicalType) - Method in class org.apache.avro.generic.GenericData
-
Returns the Conversion for the given logical type.
- getConversions() - Method in class org.apache.avro.generic.GenericData
- getConvertedType() - Method in class org.apache.avro.Conversion
-
Return the Java class representing the logical type.
- getConvertedType() - Method in class org.apache.avro.Conversions.BigDecimalConversion
- getConvertedType() - Method in class org.apache.avro.Conversions.DecimalConversion
- getConvertedType() - Method in class org.apache.avro.Conversions.DurationConversion
- getConvertedType() - Method in class org.apache.avro.Conversions.UUIDConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.DateConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMicrosConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMillisConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampNanosConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.TimeMicrosConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.TimeMillisConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.TimestampMillisConversion
- getConvertedType() - Method in class org.apache.avro.data.TimeConversions.TimestampNanosConversion
- getConvertedType() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMicrosConversion
- getConvertedType() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
- getConvertedType() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampNanosConversion
- getCount() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Segment
-
Return the total number of references in this segment.
- 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
- getCustomRegisteredTypes() - Static method in class org.apache.avro.LogicalTypes
-
Return an unmodifiable map of any registered custom
LogicalType
- 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/serialization.
- 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.netty.NettyTransportCodec.NettyDataPack
- getDatumReader(Schema) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Deprecated.
- 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, 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
- getDays() - Method in class org.apache.avro.util.TimePeriod
- getDecoder() - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Return the BinaryMessageDecoder instance used by this class.
- getDecoder() - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Return the BinaryMessageDecoder instance used by this class.
- getDecoder(ObjectInput) - Static method in class org.apache.avro.specific.SpecificData
-
Runtime utility used by generated classes.
- getDefaultFormatter() - Method in class org.apache.avro.CanonicalSchemaFormatterFactory
- getDefaultFormatter() - Method in class org.apache.avro.idl.IdlSchemaFormatterFactory
- getDefaultFormatter() - Method in class org.apache.avro.JsonSchemaFormatterFactory
- getDefaultFormatter() - Method in interface org.apache.avro.SchemaFormatterFactory
-
Get the default formatter for this schema format.
- 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.
- getDouble(int) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
-
Direct primitive int access.
- getElementType() - Method in class org.apache.avro.Schema
-
If this is an array, returns its element type.
- getEncoder() - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Return the BinaryMessageEncoder instance used by this class.
- getEncoder() - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Return the BinaryMessageEncoder instance used by this class.
- getEncoder(ObjectOutput) - Static method in class org.apache.avro.specific.SpecificData
-
Runtime utility used by generated classes.
- getEnumDefault() - Method in class org.apache.avro.Schema
-
If this is an enum, return its default value.
- 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.NameValidator.Result
- getErrors() - Method in class org.apache.avro.Protocol.Message
-
Errors that might be thrown.
- getExecutable(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
-
Get the URI of the application's executable.
- getExpected() - Method in class org.apache.avro.generic.GenericDatumReader
-
Get the reader's schema.
- getFastReaderBuilder() - Method in class org.apache.avro.generic.GenericData
- getField(Object, String, int) - Method in class org.apache.avro.generic.GenericData
-
Called by
GenericDatumReader.readRecord(java.lang.Object, org.apache.avro.Schema, org.apache.avro.io.ResolvingDecoder)
to retrieve a record field value from a reused instance. - getField(Object, String, int) - Method in class org.apache.avro.protobuf.ProtobufData
- getField(Object, String, int) - Method in class org.apache.avro.reflect.ReflectData
- getField(Object, String, int) - Method in class org.apache.avro.thrift.ThriftData
- getField(Object, String, int, Object) - Method in class org.apache.avro.generic.GenericData
-
Version of
GenericData.getField(java.lang.Object, java.lang.String, int)
that has state. - getField(Object, String, int, Object) - Method in class org.apache.avro.protobuf.ProtobufData
- getField(Object, String, int, Object) - Method in class org.apache.avro.reflect.ReflectData
- getField(Object, String, int, Object) - Method in class org.apache.avro.thrift.ThriftData
- getField(String) - Method in class org.apache.avro.Schema
-
If this is a record, returns the Field with the given name fieldName.
- getFieldAccess() - Static method in class org.apache.avro.reflect.ReflectionUtil
- 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.
- getFloat(int) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
-
Direct primitive int access.
- getForClass(Class<T>) - Static method in class org.apache.avro.specific.SpecificData
-
If the given class is assignable to
SpecificRecordBase
, this method returns the SpecificData instance from the fieldMODEL$
, in order to get the correctConversion
instances for the class. - getFormatterForVariant(String) - Method in class org.apache.avro.JsonSchemaFormatterFactory
- getFormatterForVariant(String) - Method in interface org.apache.avro.SchemaFormatterFactory
-
Get a formatter for the specified schema format variant, if multiple variants are supported.
- getForSchema(Schema) - Static method in class org.apache.avro.specific.SpecificData
-
For RECORD and UNION type schemas, this method returns the SpecificData instance of the class associated with the schema, in order to get the right conversions for any logical types used.
- 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
- getGrammarFileName() - Method in class org.apache.avro.idl.IdlLexer
- getGrammarFileName() - Method in class org.apache.avro.idl.IdlParser
- 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.
- getHash() - Method in interface org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Reference
-
Return the hash for the reference.
- getHash(Object) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Get the hash for a given object, apply an additional hash function to reduce collisions.
- getHeader() - Method in class org.apache.avro.file.DataFileStream
-
A handle that can be used to reopen this stream without rereading the head.
- getIncludes() - Method in class org.apache.avro.mojo.AbstractAvroMojo
- getIncludes() - Method in class org.apache.avro.mojo.IDLMojo
- getIncludes() - Method in class org.apache.avro.mojo.ProtocolMojo
- getIncludes() - Method in class org.apache.avro.mojo.SchemaMojo
- getIncompatibilities() - Method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
-
If the compatibility is INCOMPATIBLE, returns
Incompatibilities
found, otherwise an empty list. - 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.
- getInitializationStage() - Method in class org.apache.avro.io.FastReaderBuilder.RecordReader
- 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.
- getInstance(String) - Static method in interface org.apache.avro.SchemaFormatter
-
Get the schema formatter for the specified format name with optional variant.
- getInt(int) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
-
Direct primitive int access.
- getJavaClassName(Schema) - Static method in class org.apache.avro.compiler.schema.Schemas
- getKey() - Method in class org.apache.avro.hadoop.io.AvroKeyValue
-
Read the key.
- getKey() - Method in class org.apache.avro.path.MapKeyPredicate
- getKey() - Method in class org.apache.avro.reflect.MapEntry
-
Deprecated.
- getKey() - Method in class org.apache.avro.util.MapEntry
- getKey() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Entry
- 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
- getLength() - Method in class org.apache.avro.util.Utf8
-
Deprecated.call
Utf8.getByteLength()
instead. - getLoadFactor() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- getLocal() - Method in class org.apache.avro.ipc.Requestor
- getLocal() - Method in class org.apache.avro.ipc.Responder
-
Return the local protocol.
- getLocation() - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
-
Returns a JSON Pointer describing the node location within the schema's JSON document tree where the incompatibility was encountered.
- getLogicalType() - Method in class org.apache.avro.Schema
- getLogicalTypeName() - Method in class org.apache.avro.Conversion
-
Return the logical type this class converts.
- getLogicalTypeName() - Method in class org.apache.avro.Conversions.BigDecimalConversion
- getLogicalTypeName() - Method in class org.apache.avro.Conversions.DecimalConversion
- getLogicalTypeName() - Method in class org.apache.avro.Conversions.DurationConversion
- getLogicalTypeName() - Method in class org.apache.avro.Conversions.UUIDConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.DateConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMicrosConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMillisConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampNanosConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.TimeMicrosConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.TimeMillisConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.TimestampMillisConversion
- getLogicalTypeName() - Method in class org.apache.avro.data.TimeConversions.TimestampNanosConversion
- getLogicalTypeName() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMicrosConversion
- getLogicalTypeName() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
- getLogicalTypeName() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampNanosConversion
- getLong(int) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
-
Direct primitive int access.
- getLong(String) - Method in class org.apache.trevni.MetaData
-
Return the value of a metadata property as a long.
- getMainSchema() - Method in class org.apache.avro.idl.IdlFile
-
The (main) schema defined by the IDL file.
- 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.
- getMD5() - Method in class org.apache.avro.Protocol
-
Return the MD5 hash of the text of this protocol.
- getMessage() - Method in class org.apache.avro.ipc.RPCContext
-
Returns the
Protocol.Message
corresponding to this RPC - getMessage() - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
-
Returns a human-readable message with more details about what failed.
- getMessages() - Method in class org.apache.avro.Protocol
-
The messages of this protocol.
- 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.
- 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.
- 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.
- getMillis() - Method in class org.apache.avro.util.TimePeriod
- getModeNames() - Method in class org.apache.avro.idl.IdlLexer
- getMonths() - Method in class org.apache.avro.util.TimePeriod
- getname() - Method in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
- 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.DeflateCodec
- getName() - Method in class org.apache.avro.file.SnappyCodec
- getName() - Method in class org.apache.avro.file.XZCodec
- getName() - Method in class org.apache.avro.file.ZstandardCodec
- getName() - Method in class org.apache.avro.LogicalType
-
Get the name of this logical type.
- 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.DataFileRepairTool
- 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.RecordCountTool
- 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.SchemaFingerprintTool
- getName() - Method in class org.apache.avro.tool.SchemaNormalizationTool
- 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.
- getNamedSchema(String) - Method in class org.apache.avro.idl.IdlFile
-
Get a named schema defined by the IDL file, by name.
- getNamedSchema(String) - Method in class org.apache.avro.ParseContext
-
Get a schema by name.
- getNamedSchemas() - Method in class org.apache.avro.idl.IdlFile
-
The named schemas defined by the IDL file, mapped by their full name.
- 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.
- getNamespace(Descriptors.FileDescriptor, Descriptors.Descriptor) - Method in class org.apache.avro.protobuf.ProtobufData
- getNameValidator() - Static method in class org.apache.avro.Schema
-
Deprecated.
- getNewRecordSupplier(Schema) - Method in class org.apache.avro.generic.GenericData
-
create a supplier that allows to get new record instances for a given schema in an optimized way
- getNewRecordSupplier(Schema) - Method in class org.apache.avro.specific.SpecificData
- getNext() - Method in interface org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Reference
-
Return the next reference in the chain, or
null
if none. - getNonNullIndex(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- getNullOutputStream() - Method in class org.apache.avro.perf.test.BasicState
- getNumActiveConnections() - Method in class org.apache.avro.ipc.netty.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
- getObjectProp(String) - Method in class org.apache.avro.JsonProperties
-
Returns the value of the named property in this schema.
- getObjectProp(String, Object) - Method in class org.apache.avro.JsonProperties
- getObjectProps() - Method in class org.apache.avro.JsonProperties
-
Return the defined properties as an unmodifiable Map.
- getOptionalClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'clientHash' field as an Optional<org.apache.avro.ipc.MD5>.
- getOptionalClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'clientHash' field as an Optional<org.apache.avro.ipc.MD5>.
- getOptionalClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'clientProtocol' field as an Optional<java.lang.String>.
- getOptionalClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'clientProtocol' field as an Optional<java.lang.String>.
- getOptionalMatch() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'match' field as an Optional<org.apache.avro.ipc.HandshakeMatch>.
- getOptionalMatch() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'match' field as an Optional<org.apache.avro.ipc.HandshakeMatch>.
- getOptionalMeta() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'meta' field as an Optional<java.util.Map<java.lang.String,java.nio.ByteBuffer>>.
- getOptionalMeta() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'meta' field as an Optional<java.util.Map<java.lang.String,java.nio.ByteBuffer>>.
- getOptionalMeta() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'meta' field as an Optional<java.util.Map<java.lang.String,java.nio.ByteBuffer>>.
- getOptionalMeta() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'meta' field as an Optional<java.util.Map<java.lang.String,java.nio.ByteBuffer>>.
- getOptionalServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'serverHash' field as an Optional<org.apache.avro.ipc.MD5>.
- getOptionalServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'serverHash' field as an Optional<org.apache.avro.ipc.MD5>.
- getOptionalServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'serverHash' field as an Optional<org.apache.avro.ipc.MD5>.
- getOptionalServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'serverHash' field as an Optional<org.apache.avro.ipc.MD5>.
- getOptionalServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'serverProtocol' field as an Optional<java.lang.String>.
- getOptionalServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'serverProtocol' field as an Optional<java.lang.String>.
- getOrCreateDefaultValue(Type) - Method in class org.apache.avro.reflect.ReflectData
-
Get or create new value instance for a type.
- getOrCreateDefaultValue(Type, Field) - Method in class org.apache.avro.reflect.ReflectData
-
Get or create new value instance for a field
- getOrDefault(Object, V) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- 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.
- getParsedNamedSchemas() - Method in class org.apache.avro.SchemaParser
-
Get all parsed schemata.
- getPartial() - Method in class org.apache.avro.grpc.AvroInputStream
- 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.jetty.HttpServer
- getPort() - Method in class org.apache.avro.ipc.netty.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
- getPrecision() - Method in class org.apache.avro.LogicalTypes.Decimal
- getPrimitiveTypeCache() - Method in class org.apache.avro.generic.GenericData
-
Called to obtain the primitive type cache.
- 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.
- getProtocol() - Method in class org.apache.avro.idl.IdlFile
-
The protocol defined by the IDL file.
- getProtocol(Class) - Static method in class org.apache.avro.grpc.AvroGrpcUtils
-
Gets the
Protocol
from the Avro Interface. - 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.
- getProtocol(JobConf) - Static method in class org.apache.avro.mapred.tether.TetherJob
-
Extract from the job configuration file an instance of the TRANSPROTO enumeration to represent the protocol to use for the communication
- getRandom() - Method in class org.apache.avro.perf.test.BasicState
- getReader() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets the reader schema that was validated.
- getReaderFragment() - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
-
Returns the fragment of the reader schema that failed compatibility check.
- getReaderSchema() - Method in class org.apache.avro.hadoop.io.AvroDeserializer
-
Gets the reader schema used for deserializing.
- getRecommendedSchema() - Method in class org.apache.avro.Conversion
- getRecommendedSchema() - Method in class org.apache.avro.Conversions.BigDecimalConversion
- getRecommendedSchema() - Method in class org.apache.avro.Conversions.DecimalConversion
- getRecommendedSchema() - Method in class org.apache.avro.Conversions.DurationConversion
- getRecommendedSchema() - Method in class org.apache.avro.Conversions.UUIDConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.DateConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMicrosConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMillisConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.LocalTimestampNanosConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.TimeMicrosConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.TimeMillisConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.TimestampMillisConversion
- getRecommendedSchema() - Method in class org.apache.avro.data.TimeConversions.TimestampNanosConversion
- getRecommendedSchema() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMicrosConversion
- getRecommendedSchema() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
- getRecommendedSchema() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampNanosConversion
- 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
-
Produce state for repeated calls to
GenericData.getField(Object,String,int,Object)
andGenericData.setField(Object,String,int,Object,Object)
on the same record. - 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(FileSystem, JobConf, String, Progressable) - Method in class org.apache.trevni.avro.AvroTrevniOutputFormat
- 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(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyOutputFormat
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueOutputFormat
- getReference(Object, int, ConcurrentReferenceHashMap.Restructure) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Segment
- getReference(Object, ConcurrentReferenceHashMap.Restructure) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Return a
ConcurrentReferenceHashMap.Reference
to theConcurrentReferenceHashMap.Entry
for the specifiedkey
, ornull
if not found. - 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.netty.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() - Method in class org.apache.avro.ipc.Transceiver
-
Returns the protocol passed to
Transceiver.setRemote(Protocol)
. - getRemote(Object) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Return the remote protocol for a proxy.
- 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.netty.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.
- getRequestPayload() - Method in class org.apache.avro.ipc.RPCContext
-
Returns the serialized payload of the request in this RPC.
- getResolved(Schema) - Method in class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- 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.jetty.StaticServlet
- 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.
- getResult() - Method in class org.apache.avro.ipc.CallFuture
-
Gets the value of the RPC result without blocking.
- getResult() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets more details about the compatibility, in particular if getType() is INCOMPATIBLE.
- 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.
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.EnumDefaultContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.FormalParameterContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.FullTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.JsonPairContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.JsonValueContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.MapTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.NamedSchemaDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.NullableTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.PlainTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.RecordBodyContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.ResultTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- getRuleIndex() - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- getRuleNames() - Method in class org.apache.avro.idl.IdlLexer
- getRuleNames() - Method in class org.apache.avro.idl.IdlParser
- getScale() - Method in class org.apache.avro.LogicalTypes.Decimal
- 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.AbstractArray
- 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() - Method in enum org.apache.avro.ipc.HandshakeMatch
- 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.MD5
- getSchema() - Method in class org.apache.avro.mapred.Pair
- getSchema() - Method in class org.apache.avro.mapred.SequenceFileReader
- getSchema() - Method in enum org.apache.avro.mapred.tether.TaskType
- getSchema() - Method in class org.apache.avro.reflect.CustomEncoding
- getSchema() - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- getSchema() - Method in class org.apache.avro.specific.SpecificFixed
- getSchema(Descriptors.Descriptor) - Method in class org.apache.avro.protobuf.ProtobufData
- getSchema(Descriptors.EnumDescriptor) - Method in class org.apache.avro.protobuf.ProtobufData
- getSchema(Descriptors.FieldDescriptor) - Method in class org.apache.avro.protobuf.ProtobufData
- getSchema(Class) - Method in class org.apache.avro.protobuf.ProtobufData
-
Return a record schema given a protobuf message class.
- getSchema(Class) - Method in class org.apache.avro.thrift.ThriftData
-
Return a record schema given a thrift generated class.
- getSchema(Type) - Method in class org.apache.avro.specific.SpecificData
-
Find the schema for a Java type.
- getSchema(Schema, Schema) - Static method in class org.apache.avro.hadoop.io.AvroKeyValue
-
Creates a KeyValuePair generic record schema.
- 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
- getSchemaName(Object) - Method in class org.apache.avro.thrift.ThriftData
- getSchemaParentClass(boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- getSegment(int) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- getSegmentsSize() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- getSerial() - Method in class org.apache.avro.ipc.netty.NettyTransportCodec.NettyDataPack
- getSerializedATN() - Method in class org.apache.avro.idl.IdlLexer
- getSerializedATN() - Method in class org.apache.avro.idl.IdlParser
- 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.
- getServiceName(Class) - Static method in class org.apache.avro.grpc.AvroGrpcUtils
-
Provides a a unique gRPC service name for Avro RPC interface or its subclass Callback Interface.
- 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.DataFileRepairTool
- 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.RecordCountTool
- 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.SchemaFingerprintTool
- getShortDescription() - Method in class org.apache.avro.tool.SchemaNormalizationTool
- 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
- getSize() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Segment
-
Return the size of the current references array.
- getSpecific() - Static method in class org.apache.avro.io.FastReaderBuilder
- getSpecificData() - Method in class org.apache.avro.ipc.HandshakeRequest
- getSpecificData() - Method in class org.apache.avro.ipc.HandshakeResponse
- 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. - getSpecificData() - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- getSpecificData() - Method in class org.apache.avro.specific.SpecificRecordBase
- 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.
- getStringType(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use (and also internal use).
- 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.
- gettersReturnOptional - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
The gettersReturnOptional parameter enables generating get... methods that return an Optional of the requested type.
- getTestIncludes() - Method in class org.apache.avro.mojo.AbstractAvroMojo
- getTestIncludes() - Method in class org.apache.avro.mojo.IDLMojo
- getTestIncludes() - Method in class org.apache.avro.mojo.ProtocolMojo
- getTestIncludes() - Method in class org.apache.avro.mojo.SchemaMojo
- getTokenNames() - Method in class org.apache.avro.idl.IdlLexer
-
Deprecated.
- getTokenNames() - Method in class org.apache.avro.idl.IdlParser
-
Deprecated.
- 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. - getTrustedPackages() - Method in class org.apache.avro.specific.SpecificDatumReader
- getType() - Method in class org.apache.avro.Schema
-
Return the type of this schema.
- getType() - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
-
Returns the SchemaIncompatibilityType.
- 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.
- getType(String) - Method in class org.apache.avro.Protocol
-
Returns the named type.
- getTypeName() - Method in interface org.apache.avro.LogicalTypes.LogicalTypeFactory
- 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 class org.apache.avro.UnresolvedUnionException
- getUnits() - Method in class org.apache.avro.util.TimePeriod
- getUnresolvedDatum() - Method in exception class org.apache.avro.UnresolvedUnionException
- getUnresolvedSchemaName(Schema) - Static method in class org.apache.avro.util.SchemaResolver
-
Get the unresolved schema name.
- getUnresolvedTypes() - Method in class org.apache.avro.Protocol
-
Deprecated.can return invalid schemata: do NOT use!
- getUsedConversionClasses(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- getUsedCustomLogicalTypeFactories(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- getValidateDefaults() - Static method in class org.apache.avro.Schema
-
Deprecated.
- getValidateDefaults() - Method in class org.apache.avro.Schema.Parser
-
True iff default values are validated.
- getValue() - Method in exception class org.apache.avro.AvroRemoteException
- 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.reflect.MapEntry
-
Deprecated.
- getValue() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
- getValue() - Method in class org.apache.avro.util.MapEntry
- getValue() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Entry
- 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(int) - Method in class org.apache.trevni.ColumnFileReader
-
Return an iterator over values in a column.
- getValues(String) - Method in class org.apache.trevni.ColumnFileReader
-
Return an iterator over values in the named 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.
- getVocabulary() - Method in class org.apache.avro.idl.IdlLexer
- getVocabulary() - Method in class org.apache.avro.idl.IdlParser
- getWarnings() - Method in class org.apache.avro.idl.IdlFile
- getWarnings(String) - Method in class org.apache.avro.idl.IdlFile
- getWriter() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets the writer schema that was validated.
- getWriterFragment() - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
-
Returns the fragment of the writer schema that failed compatibility check.
- 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.
- getWrittenCount() - Method in class org.apache.avro.grpc.AvroInputStream.CountingOutputStream
- GT - Static variable in class org.apache.avro.idl.IdlLexer
- GT - Static variable in class org.apache.avro.idl.IdlParser
- GT() - Method in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- GT() - Method in class org.apache.avro.idl.IdlParser.MapTypeContext
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 todeflate
org.apache.hadoop.io.compress.SnappyCodec
will map tosnappy
org.apache.hadoop.io.compress.BZip2Codec
will map tobzip2
org.apache.hadoop.io.compress.GZipCodec
will map todeflate
org.apache.hadoop.io.compress.ZStandardCodec
will map tozstandard
- HadoopCodecFactory() - Constructor for class org.apache.avro.hadoop.file.HadoopCodecFactory
- HadoopInput - Class in org.apache.trevni.avro
-
Adapt a Hadoop
FSDataInputStream
to Trevni'sInput
. - 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()
orCallFuture.get(long, TimeUnit)
. - handleError(Throwable) - Method in class org.apache.avro.ipc.Requestor.TransceiverCallback
- handleResult(List<ByteBuffer>) - 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()
orCallFuture.get(long, TimeUnit)
. - 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(int) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Checks whether a field has been set.
- 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.
- hasBuilder(Schema) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for use by templates.
- 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.
- hasCustomCoders() - Method in class org.apache.avro.ipc.HandshakeRequest
- hasCustomCoders() - Method in class org.apache.avro.ipc.HandshakeResponse
- hasCustomCoders() - Method in class org.apache.avro.specific.SpecificRecordBase
-
Returns true iff an instance supports the
MessageEncoder.encode(D)
andMessageDecoder.decode(java.io.InputStream)
operations. - hasDefaultValue() - Method in class org.apache.avro.Schema.Field
- hasEnumSymbol(String) - Method in class org.apache.avro.Schema
-
If this is an enum, returns true if it contains given symbol.
- hasErrors(Symbol) - Static method in class org.apache.avro.io.parsing.Symbol
-
Returns true if the Parser contains any Error symbol, indicating that it may fail for some inputs.
- hasField(String) - Method in interface org.apache.avro.generic.GenericRecord
-
Return true if record has field with name: key
- hasFields() - Method in class org.apache.avro.Schema
-
If this is a record, returns whether the fields have been set.
- hasGeneratedJavaClass(Schema) - Static method in class org.apache.avro.compiler.schema.Schemas
- 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.DeflateCodec
- hashCode() - Method in class org.apache.avro.file.SnappyCodec
- hashCode() - Method in class org.apache.avro.file.XZCodec
- hashCode() - Method in class org.apache.avro.file.ZstandardCodec
- hashCode() - Method in class org.apache.avro.generic.GenericData.AbstractArray
- hashCode() - Method in class org.apache.avro.generic.GenericData.EnumSymbol
- hashCode() - Method in class org.apache.avro.generic.GenericData.Fixed
- hashCode() - Method in class org.apache.avro.generic.GenericData.Record
- hashCode() - Method in class org.apache.avro.generic.GenericRecordBuilder
- hashCode() - Method in class org.apache.avro.LogicalTypes.Decimal
- 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.Schema.SeenPair
- hashCode() - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
- hashCode() - Method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
- hashCode() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
- hashCode() - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- hashCode() - Method in class org.apache.avro.specific.SpecificFixed
- hashCode() - Method in class org.apache.avro.specific.SpecificRecordBase
- hashCode() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Entry
- hashCode() - Method in class org.apache.avro.util.TimePeriod
- hashCode() - Method in class org.apache.avro.util.Utf8
- hashCode() - Method in class org.apache.avro.util.WeakIdentityHashMap
- hashCode(byte[], int, int, Schema) - Static method in class org.apache.avro.io.BinaryData
-
Hash binary encoded data.
- 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)
. - hasIndexValues() - Method in class org.apache.trevni.ColumnMetaData
-
Get whether this column has an index of blocks by value.
- hasIndexValues(boolean) - Method in class org.apache.trevni.ColumnMetaData
-
Set whether this column has an index of blocks by value.
- hasLogicalTypeField(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- hasMatch() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Checks whether the 'match' 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.
- hasNewSchemas() - Method in class org.apache.avro.ParseContext
- 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
- hasProps() - Method in class org.apache.avro.JsonProperties
- 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.
- 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.avro_maven_plugin
-
Display help information on avro-maven-plugin.
Callmvn avro:help -Ddetail=true -Dgoal=<goal-name>
to display parameter details. - HelpMojo() - Constructor for class org.apache.avro.avro_maven_plugin.HelpMojo
- HttpServer - Class in org.apache.avro.ipc.jetty
-
An HTTP-based RPC
Server
. - HttpServer(Responder, int) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Constructs a server to run on the named port.
- HttpServer(Responder, String, int) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Constructs a server to run on the named port on the specified address.
- HttpServer(Responder, InetSocketAddress) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Constructs a server to run on the named port on the specified address.
- HttpServer(Responder, ConnectionFactory, String, int) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Constructs a server to run with the given ConnectionFactory on the given address/port.
- HttpServer(Responder, Connector) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Deprecated.- use the Constructors that take a ConnectionFactory
- HttpServer(ResponderServlet, int) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Constructs a server to run on the named port.
- HttpServer(ResponderServlet, String, int) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Constructs a server to run on the named port on the specified address.
- HttpServer(ResponderServlet, ConnectionFactory, String, int) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Constructs a server to run with the given ConnectionFactory on the given address/port.
- HttpServer(ResponderServlet, Connector) - Constructor for class org.apache.avro.ipc.jetty.HttpServer
-
Deprecated.- use the Constructors that take a ConnectionFactory
- 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
- identifier - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.EnumDefaultContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- identifier() - Method in class org.apache.avro.idl.IdlParser
- identifier() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.NullableTypeContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- identifier() - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- identifier(int) - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- IdentifierContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.IdentifierContext
- IdentifierToken - Static variable in class org.apache.avro.idl.IdlLexer
- IdentifierToken - Static variable in class org.apache.avro.idl.IdlParser
- IdentifierToken() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- IDL - Static variable in class org.apache.avro.idl.IdlLexer
- IDL - Static variable in class org.apache.avro.idl.IdlParser
- IDL() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- IDL() - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- IdlBaseListener - Class in org.apache.avro.idl
-
This class provides an empty implementation of
IdlListener
, which can be extended to create a listener which only needs to handle a subset of the available methods. - IdlBaseListener() - Constructor for class org.apache.avro.idl.IdlBaseListener
- idlFile() - Method in class org.apache.avro.idl.IdlParser
- IdlFile - Class in org.apache.avro.idl
-
A parsed IdlFile.
- IdlFileContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.IdlFileContext
- IdlLexer - Class in org.apache.avro.idl
- IdlLexer(CharStream) - Constructor for class org.apache.avro.idl.IdlLexer
- IdlListener - Interface in org.apache.avro.idl
-
This interface defines a complete listener for a parse tree produced by
IdlParser
. - IDLMojo - Class in org.apache.avro.mojo
-
Generate Java classes and interfaces from AvroIDL files (.avdl)
- IDLMojo() - Constructor for class org.apache.avro.mojo.IDLMojo
- IdlParser - Class in org.apache.avro.idl
- IdlParser(TokenStream) - Constructor for class org.apache.avro.idl.IdlParser
- IdlParser.ArrayTypeContext - Class in org.apache.avro.idl
- IdlParser.EnumDeclarationContext - Class in org.apache.avro.idl
- IdlParser.EnumDefaultContext - Class in org.apache.avro.idl
- IdlParser.EnumSymbolContext - Class in org.apache.avro.idl
- IdlParser.FieldDeclarationContext - Class in org.apache.avro.idl
- IdlParser.FixedDeclarationContext - Class in org.apache.avro.idl
- IdlParser.FormalParameterContext - Class in org.apache.avro.idl
- IdlParser.FullTypeContext - Class in org.apache.avro.idl
- IdlParser.IdentifierContext - Class in org.apache.avro.idl
- IdlParser.IdlFileContext - Class in org.apache.avro.idl
- IdlParser.ImportStatementContext - Class in org.apache.avro.idl
- IdlParser.JsonArrayContext - Class in org.apache.avro.idl
- IdlParser.JsonLiteralContext - Class in org.apache.avro.idl
- IdlParser.JsonObjectContext - Class in org.apache.avro.idl
- IdlParser.JsonPairContext - Class in org.apache.avro.idl
- IdlParser.JsonValueContext - Class in org.apache.avro.idl
- IdlParser.MainSchemaDeclarationContext - Class in org.apache.avro.idl
- IdlParser.MapTypeContext - Class in org.apache.avro.idl
- IdlParser.MessageDeclarationContext - Class in org.apache.avro.idl
- IdlParser.NamedSchemaDeclarationContext - Class in org.apache.avro.idl
- IdlParser.NamespaceDeclarationContext - Class in org.apache.avro.idl
- IdlParser.NullableTypeContext - Class in org.apache.avro.idl
- IdlParser.PlainTypeContext - Class in org.apache.avro.idl
- IdlParser.PrimitiveTypeContext - Class in org.apache.avro.idl
- IdlParser.ProtocolDeclarationBodyContext - Class in org.apache.avro.idl
- IdlParser.ProtocolDeclarationContext - Class in org.apache.avro.idl
- IdlParser.RecordBodyContext - Class in org.apache.avro.idl
- IdlParser.RecordDeclarationContext - Class in org.apache.avro.idl
- IdlParser.ResultTypeContext - Class in org.apache.avro.idl
- IdlParser.SchemaPropertyContext - Class in org.apache.avro.idl
- IdlParser.UnionTypeContext - Class in org.apache.avro.idl
- IdlParser.VariableDeclarationContext - Class in org.apache.avro.idl
- 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
- IdlReader - Class in org.apache.avro.idl
- IdlReader() - Constructor for class org.apache.avro.idl.IdlReader
- IdlReader(ParseContext) - Constructor for class org.apache.avro.idl.IdlReader
- IdlSchemaFormatter - Class in org.apache.avro.idl
- IdlSchemaFormatter() - Constructor for class org.apache.avro.idl.IdlSchemaFormatter
- IdlSchemaFormatterFactory - Class in org.apache.avro.idl
- IdlSchemaFormatterFactory() - Constructor for class org.apache.avro.idl.IdlSchemaFormatterFactory
- IdlSchemaParser - Class in org.apache.avro.idl
- IdlSchemaParser() - Constructor for class org.apache.avro.idl.IdlSchemaParser
- 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
- IdlUtils - Class in org.apache.avro.idl
-
Utils for IDL
- IGNORE - Enum constant in enum org.apache.avro.Schema.Field.Order
- 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.
- IMPLICIT_ACTION - Enum constant in enum org.apache.avro.io.parsing.Symbol.Kind
-
non-terminal action symbol which are automatically consumed
- Import - Static variable in class org.apache.avro.idl.IdlLexer
- Import - Static variable in class org.apache.avro.idl.IdlParser
- Import() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Import() - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- imports - Variable in class org.apache.avro.idl.IdlParser.IdlFileContext
- imports - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- 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.
- importStatement - Variable in class org.apache.avro.idl.IdlParser.IdlFileContext
- importStatement - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- importStatement() - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- importStatement() - Method in class org.apache.avro.idl.IdlParser
- importStatement() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- importStatement(int) - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- importStatement(int) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- ImportStatementContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.ImportStatementContext
- importType - Variable in class org.apache.avro.idl.IdlParser.ImportStatementContext
- in - Variable in class org.apache.avro.io.ValidatingDecoder
- incompatible(SchemaCompatibility.SchemaIncompatibilityType, Schema, Schema, String, List<String>) - Static method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
-
Returns a details object representing an incompatible schema pair, including error details.
- INCOMPATIBLE - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaCompatibilityType
- INCOMPATIBLE_SCHEMA_TYPES - Enum constant in enum org.apache.avro.Resolver.ErrorAction.ErrorType
-
Use when Schema types don't match and can't be converted.
- indent(int) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- 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.
- InduceMojo - Class in org.apache.avro.mojo
-
Generate Avro files (.avsc and .avpr) from Java classes or interfaces
- InduceMojo() - Constructor for class org.apache.avro.mojo.InduceMojo
- 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
- Induction rules - Search tag in package org.apache.avro.io.parsing
- Section
- 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
- INITIALIZED - Enum constant in enum org.apache.avro.io.FastReaderBuilder.RecordReader.Stage
- INITIALIZING - Enum constant in enum org.apache.avro.io.FastReaderBuilder.RecordReader.Stage
- 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
- 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.
- 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
-
Transmit inputs to a map or reduce task sub-process.
- InputProtocol.Callback - Interface in org.apache.avro.mapred.tether
-
Transmit inputs to a map or reduce task sub-process.
- 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
-
Called by
GenericData.resolveUnion(Schema,Object)
. - instanceSupplier - Variable in class org.apache.avro.Resolver.RecordAdjust
-
Supplier that offers an optimized alternative to data.newRecord()
- instantiateAdditionalVelocityTools() - Method in class org.apache.avro.mojo.AbstractAvroMojo
- Int - Static variable in class org.apache.avro.idl.IdlLexer
- Int - Static variable in class org.apache.avro.idl.IdlParser
- Int() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Int() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- INT - Enum constant in enum org.apache.avro.Schema.Type
- INT - Enum constant in enum org.apache.trevni.ValueType
- INT - Static variable in class org.apache.avro.io.parsing.Symbol
- IntArray(int, Schema) - Constructor for class org.apache.avro.generic.PrimitivesArrays.IntArray
- IntArray(Schema, Collection<Integer>) - Constructor for class org.apache.avro.generic.PrimitivesArrays.IntArray
- 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
- IntCheckAction(int) - Constructor for class org.apache.avro.io.parsing.Symbol.IntCheckAction
-
Deprecated.
- intDefault(int) - Method in class org.apache.avro.SchemaBuilder.IntDefault
-
Completes this field with the default value provided
- IntegerLiteral - Static variable in class org.apache.avro.idl.IdlLexer
- IntegerLiteral - Static variable in class org.apache.avro.idl.IdlParser
- IntegerLiteral() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- IntegerLiteral() - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- IntegerLiteral() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- IntegerLiteral(int) - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- IntTest - Class in org.apache.avro.perf.test.basic
- IntTest() - Constructor for class org.apache.avro.perf.test.basic.IntTest
- IntTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
- IntTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_encode_jmhTest
- IntTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType
- IntTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B1
- IntTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- IntTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B3
- IntTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType
- IntTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B1
- IntTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- IntTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B3
- IntTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType
- IntTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B1
- IntTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- IntTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- IntTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B3
- IntTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- IntTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- 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.
- IntWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.IntWritableConverter
-
Constructor.
- InvalidAvroMagicException - Exception Class in org.apache.avro
- InvalidAvroMagicException(String) - Constructor for exception class org.apache.avro.InvalidAvroMagicException
- InvalidNumberEncodingException - Exception Class in org.apache.avro
- InvalidNumberEncodingException(String) - Constructor for exception class org.apache.avro.InvalidNumberEncodingException
- 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() - 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.
- isArray(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isArray(Object) - Method in class org.apache.avro.protobuf.ProtobufData
- isArray(Object) - Method in class org.apache.avro.reflect.ReflectData
-
Returns true for arrays and false otherwise, with the following exceptions:
- isBoolean(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isBytes(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - 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
- isClassPropEnabled() - Method in class org.apache.avro.io.FastReaderBuilder
- isConnected() - Method in class org.apache.avro.ipc.netty.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.
- isCreateAllArgsConstructor() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- isCreateNullSafeAnnotations() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- isCreateOptionalGetters() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- isCreateSetters() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- isCustomCodable(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- isDateBased() - Method in class org.apache.avro.util.TimePeriod
-
Determines if the TimePeriod is date based (i.e., if its milliseconds component is 0).
- isDone() - Method in class org.apache.avro.ipc.CallFuture
- isDouble(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isEmpty - Variable in class org.apache.avro.io.JsonEncoder
-
Has anything been written into the collections?
- isEmpty() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- 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
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - 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.
- isFastReaderEnabled() - Method in class org.apache.avro.generic.GenericData
- isFixed(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isFloat(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isFlushOnEveryBlock() - Method in class org.apache.avro.file.DataFileWriter
- isFullyResolvedSchema(Schema) - Static method in class org.apache.avro.util.SchemaResolver
-
Is this an unresolved schema?
- isGettersReturnOptional() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- isIncludeNamespace() - Method in class org.apache.avro.io.JsonEncoder
- isInteger(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isKeyClassEnabled() - Method in class org.apache.avro.io.FastReaderBuilder
- isLong(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isMap(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isMap(Object) - Method in class org.apache.avro.reflect.ReflectData
-
It returns false for non-string-maps because Avro writes out such maps as an array of records.
- isMultiNamedOutput(JobConf, String) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
-
Returns if a named output is multiple.
- isNullable() - Method in class org.apache.avro.Schema
-
Returns true if this record is a union type containing null.
- isOK() - Method in class org.apache.avro.NameValidator.Result
- isOneWay() - Method in class org.apache.avro.Protocol.Message
-
Returns true if this is a one-way message, with no response or errors.
- isOptionalGettersForNullableFieldsOnly() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- isRecord(Object) - Method in class org.apache.avro.generic.GenericData
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - 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
-
Called by the default implementation of
GenericData.instanceOf(org.apache.avro.Schema, java.lang.Object)
. - isStringable(Class<?>) - Method in class org.apache.avro.reflect.ReflectData
- isStringable(Class<?>) - Method in class org.apache.avro.specific.SpecificData
-
True if a class should be serialized with toString().
- isStringable(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- isStringType(Class<?>) - Method in class org.apache.avro.specific.SpecificData
-
True if a class IS a string type
- isSupportedData(GenericData) - Static method in class org.apache.avro.io.FastReaderBuilder
- isTimeBased() - Method in class org.apache.avro.util.TimePeriod
-
Determines if the TimePeriod is time based (i.e., if its months and days components are 0).
- 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
- isUnion() - Method in class org.apache.avro.Schema
-
Returns true if this record is a union type.
- isUnresolvedSchema(Schema) - Static method in class org.apache.avro.util.SchemaResolver
-
Is this an unresolved schema.
- isValid(Schema, Schema) - Static method in class org.apache.avro.Resolver.Promote
-
Returns true iff w and r are both primitive types and either they are the same type or w is promotable to r.
- isValidDefault(JsonNode) - Method in class org.apache.avro.Schema
-
Checks if a JSON value matches the schema.
- 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.AbstractArray
- 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.avro.util.RandomData
- iterator() - Method in class org.apache.trevni.avro.AvroColumnReader
- iterator() - Method in class org.apache.trevni.ColumnValues
- 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.
J
- javaAnnotations(JsonProperties) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- javaEscape(String) - 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
-
Deprecated.use javaUnbox(Schema, boolean), kept for backward compatibility of custom templates
- javaUnbox(Schema, boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- job - Variable in class org.apache.avro.tool.TetherTool
- join() - Method in class org.apache.avro.ipc.jetty.HttpServer
- join() - Method in class org.apache.avro.ipc.netty.NettyServer
- join() - Method in interface org.apache.avro.ipc.Server
-
Wait for this server to exit.
- Json - Class in org.apache.avro.data
-
Utilities for reading and writing arbitrary Json data in Avro format.
- Json.ObjectReader - Class in org.apache.avro.data
-
DatumReader
for arbitrary Json data using the object model described inJsonProperties
. - Json.ObjectWriter - Class in org.apache.avro.data
-
DatumWriter
for arbitrary Json data using the object model described inJsonProperties
. - jsonArray() - Method in class org.apache.avro.idl.IdlParser
- jsonArray() - Method in class org.apache.avro.idl.IdlParser.JsonValueContext
- JsonArrayContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.JsonArrayContext
- jsonDecoder(Schema, InputStream) - Method in class org.apache.avro.io.DecoderFactory
-
Creates a
JsonDecoder
using the InputStream 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. - 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, OutputStream, boolean, 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 - Class in org.apache.avro.io
-
An
Encoder
for Avro's JSON data encoding. - 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
- jsonLiteral() - Method in class org.apache.avro.idl.IdlParser
- jsonLiteral() - Method in class org.apache.avro.idl.IdlParser.JsonValueContext
- JsonLiteralContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.JsonLiteralContext
- jsonObject() - Method in class org.apache.avro.idl.IdlParser
- jsonObject() - Method in class org.apache.avro.idl.IdlParser.JsonValueContext
- JsonObjectContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.JsonObjectContext
- jsonPair - Variable in class org.apache.avro.idl.IdlParser.JsonObjectContext
- jsonPair() - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- jsonPair() - Method in class org.apache.avro.idl.IdlParser
- jsonPair(int) - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- JsonPairContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.JsonPairContext
- jsonPairs - Variable in class org.apache.avro.idl.IdlParser.JsonObjectContext
- JsonProperties - Class in org.apache.avro
-
Base class for objects that have JSON-valued properties.
- JsonProperties.Null - Class in org.apache.avro
- JsonSchemaFormatter - Class in org.apache.avro
- JsonSchemaFormatter(boolean) - Constructor for class org.apache.avro.JsonSchemaFormatter
- JsonSchemaFormatterFactory - Class in org.apache.avro
- JsonSchemaFormatterFactory() - Constructor for class org.apache.avro.JsonSchemaFormatterFactory
- JsonSchemaParser - Class in org.apache.avro
-
Schema parser for JSON formatted schemata.
- JsonSchemaParser() - Constructor for class org.apache.avro.JsonSchemaParser
- 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
- jsonValue - Variable in class org.apache.avro.idl.IdlParser.JsonArrayContext
- jsonValue() - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- jsonValue() - Method in class org.apache.avro.idl.IdlParser.JsonPairContext
- jsonValue() - Method in class org.apache.avro.idl.IdlParser
- jsonValue() - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- jsonValue() - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- jsonValue(int) - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- JsonValueContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.JsonValueContext
- jsonValues - Variable in class org.apache.avro.idl.IdlParser.JsonArrayContext
K
- key() - Method in class org.apache.avro.mapred.Pair
-
Get the key.
- key() - Element in annotation type org.apache.avro.reflect.AvroMeta
- 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.io.parsing.Symbol
L
- labels - Variable in class org.apache.avro.io.parsing.Symbol.Alternative
- LATENCY_SEGMENTER - Static variable in class org.apache.avro.ipc.stats.StatsPlugin
-
Static declaration of histogram buckets.
- LBrace - Static variable in class org.apache.avro.idl.IdlLexer
- LBrace - Static variable in class org.apache.avro.idl.IdlParser
- LBrace() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- LBrace() - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- LBrace() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- LBrace() - Method in class org.apache.avro.idl.IdlParser.RecordBodyContext
- LBrace() - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- LBracket - Static variable in class org.apache.avro.idl.IdlLexer
- LBracket - Static variable in class org.apache.avro.idl.IdlParser
- LBracket() - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- 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
- 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
- literal - Variable in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- LocalTimestamp - Static variable in class org.apache.avro.idl.IdlLexer
- LocalTimestamp - Static variable in class org.apache.avro.idl.IdlParser
- LocalTimestamp() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- LocalTimestamp() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- localTimestampMicros() - Static method in class org.apache.avro.LogicalTypes
- LocalTimestampMicrosConversion() - Constructor for class org.apache.avro.data.TimeConversions.LocalTimestampMicrosConversion
- localTimestampMillis() - Static method in class org.apache.avro.LogicalTypes
- LocalTimestampMillisConversion() - Constructor for class org.apache.avro.data.TimeConversions.LocalTimestampMillisConversion
- localTimestampNanos() - Static method in class org.apache.avro.LogicalTypes
- LocalTimestampNanosConversion() - Constructor for class org.apache.avro.data.TimeConversions.LocalTimestampNanosConversion
- LocalTransceiver - Class in org.apache.avro.ipc
-
Implementation of IPC that remains in process.
- LocalTransceiver(Responder) - Constructor for class org.apache.avro.ipc.LocalTransceiver
- location - Variable in class org.apache.avro.idl.IdlParser.ImportStatementContext
- LocationStep - Class in org.apache.avro.path
-
Selects items based on their "path" (name of a property under which they are stored) relative to the context.
- LocationStep(String, String) - Constructor for class org.apache.avro.path.LocationStep
- lockChannel() - Method in class org.apache.avro.ipc.netty.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.
- LOGICAL_TYPE_PROP - Static variable in class org.apache.avro.LogicalType
- logicalType - Variable in class org.apache.avro.Resolver.Action
-
If the reader has a logical type, it's stored here for fast access, otherwise this will be null.
- LogicalType - Class in org.apache.avro
-
Logical types provides an opt-in way to extend Avro's types.
- LogicalType(String) - Constructor for class org.apache.avro.LogicalType
- LogicalTypes - Class in org.apache.avro
- LogicalTypes() - Constructor for class org.apache.avro.LogicalTypes
- LogicalTypes.BigDecimal - Class in org.apache.avro
- LogicalTypes.Date - Class in org.apache.avro
-
Date represents a date without a time
- LogicalTypes.Decimal - Class in org.apache.avro
-
Decimal represents arbitrary-precision fixed-scale decimal numbers
- LogicalTypes.Duration - Class in org.apache.avro
-
Duration represents a duration, consisting on months, days and milliseconds
- LogicalTypes.LocalTimestampMicros - Class in org.apache.avro
- LogicalTypes.LocalTimestampMillis - Class in org.apache.avro
- LogicalTypes.LocalTimestampNanos - Class in org.apache.avro
- LogicalTypes.LogicalTypeFactory - Interface in org.apache.avro
-
Factory interface and SPI for logical types.
- LogicalTypes.TimeMicros - Class in org.apache.avro
-
TimeMicros represents a time in microseconds without a date
- LogicalTypes.TimeMillis - Class in org.apache.avro
-
TimeMillis represents a time in milliseconds without a date
- LogicalTypes.TimestampMicros - Class in org.apache.avro
-
TimestampMicros represents a date and time in microseconds
- LogicalTypes.TimestampMillis - Class in org.apache.avro
-
TimestampMillis represents a date and time in milliseconds
- LogicalTypes.TimestampNanos - Class in org.apache.avro
-
TimestampNanos represents a date and time in nanoseconds
- LogicalTypes.Uuid - Class in org.apache.avro
-
Uuid represents a uuid without a time
- Long - Static variable in class org.apache.avro.idl.IdlLexer
- Long - Static variable in class org.apache.avro.idl.IdlParser
- Long() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Long() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- LONG - Enum constant in enum org.apache.avro.Schema.Type
- LONG - Enum constant in enum org.apache.trevni.ValueType
- LONG - Static variable in class org.apache.avro.io.parsing.Symbol
- LongArray(int, Schema) - Constructor for class org.apache.avro.generic.PrimitivesArrays.LongArray
- LongArray(Schema, Collection<Long>) - Constructor for class org.apache.avro.generic.PrimitivesArrays.LongArray
- 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
- LongTest - Class in org.apache.avro.perf.test.basic
- LongTest() - Constructor for class org.apache.avro.perf.test.basic.LongTest
- LongTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
- LongTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_encode_jmhTest
- LongTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType
- LongTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B1
- LongTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- LongTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B3
- LongTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType
- LongTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B1
- LongTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- LongTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B3
- LongTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType
- LongTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B1
- LongTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- LongTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- LongTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B3
- LongTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- LongTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- 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.
- LongWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.LongWritableConverter
-
Constructor.
- 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 class org.apache.avro.idl.IdlLexer
- LParen - Static variable in class org.apache.avro.idl.IdlParser
- LParen() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- LParen() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- LParen() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- LParen() - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- LT - Static variable in class org.apache.avro.idl.IdlLexer
- LT - Static variable in class org.apache.avro.idl.IdlParser
- LT() - Method in class org.apache.avro.idl.IdlParser.ArrayTypeContext
- LT() - Method in class org.apache.avro.idl.IdlParser.MapTypeContext
M
- MAGIC - Static variable in class org.apache.avro.file.DataFileConstants
- main(String[]) - Static method in class org.apache.avro.compiler.specific.SchemaTask
- 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.perf.Perf
- main(String[]) - Static method in class org.apache.avro.Protocol
- main(String[]) - Static method in class org.apache.avro.tool.Main
- main(String[]) - Static method in class org.apache.avro.util.RandomData
- Main - Class in org.apache.avro.tool
-
Command-line driver.
- mainSchema - Variable in class org.apache.avro.idl.IdlParser.IdlFileContext
- mainSchema - Variable in class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- mainSchema() - Method in interface org.apache.avro.SchemaParser.ParseResult
-
The main schema parsed from a file.
- mainSchemaDeclaration() - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- mainSchemaDeclaration() - Method in class org.apache.avro.idl.IdlParser
- MainSchemaDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- 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) - Static method in class org.apache.avro.specific.SpecificData
-
Utility for template use.
- mangle(String, boolean) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- mangle(String, boolean) - Static method in class org.apache.avro.specific.SpecificData
-
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>) - Static method in class org.apache.avro.specific.SpecificData
-
Utility for template use.
- mangle(String, Set<String>, boolean) - 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.specific.SpecificData
-
Utility for template use.
- mangleFullyQualified(String) - Static method in class org.apache.avro.specific.SpecificData
-
Utility to mangle the fully qualified class name into a valid symbol.
- mangleMethod(String, boolean) - Static method in class org.apache.avro.specific.SpecificData
- mangleTypeIdentifier(String) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- mangleTypeIdentifier(String) - Static method in class org.apache.avro.specific.SpecificData
-
Utility for template use.
- mangleTypeIdentifier(String, boolean) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- mangleTypeIdentifier(String, boolean) - Static method in class org.apache.avro.specific.SpecificData
-
Utility for template use.
- 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(IN, AvroCollector<OUT>, Reporter) - Method in class org.apache.avro.mapred.AvroMapper
-
Called with each map input datum.
- Map - Static variable in class org.apache.avro.idl.IdlLexer
- Map - Static variable in class org.apache.avro.idl.IdlParser
- Map() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Map() - Method in class org.apache.avro.idl.IdlParser.MapTypeContext
- MAP - Enum constant in enum org.apache.avro.mapred.tether.TaskType
- MAP - Enum constant in enum org.apache.avro.Schema.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
- MapEntry<K,
V> - Class in org.apache.avro.reflect -
Deprecated.Use org.apache.avro.util.MapEntry
- MapEntry<K,
V> - Class in org.apache.avro.util -
An implementation of
Map.Entry
with well-defined member names. - MapEntry(K, V) - Constructor for class org.apache.avro.reflect.MapEntry
-
Deprecated.
- MapEntry(K, V) - Constructor for class org.apache.avro.util.MapEntry
- MapKeyPredicate - Class in org.apache.avro.path
-
Returns items by their position (string key under which they are stored) in a map
- MapKeyPredicate(String) - Constructor for class org.apache.avro.path.MapKeyPredicate
- 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
- MapReader(FastReaderBuilder.FieldReader, FastReaderBuilder.FieldReader) - Constructor for class org.apache.avro.io.FastReaderBuilder.MapReader
- MapTest - Class in org.apache.avro.perf.test.basic
- MapTest() - Constructor for class org.apache.avro.perf.test.basic.MapTest
- MapTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
- MapTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_encode_jmhTest
- MapTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType
- MapTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B1
- MapTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- MapTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B3
- MapTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType
- MapTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B1
- MapTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- MapTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B3
- MapTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType
- MapTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B1
- MapTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- MapTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- MapTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B3
- MapTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- MapTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- mapType() - Method in class org.apache.avro.idl.IdlParser
- mapType() - Method in class org.apache.avro.idl.IdlParser.PlainTypeContext
- MapTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.MapTypeContext
- MapUtil - Class in org.apache.avro.util
- mark(int) - Method in class org.apache.avro.util.ReusableByteBufferInputStream
- markSupported() - Method in class org.apache.avro.util.ReusableByteBufferInputStream
- MAX_BYTES_LENGTH_PROPERTY - Static variable in exception class org.apache.avro.SystemLimitException
- MAX_COLLECTION_LENGTH_PROPERTY - Static variable in exception class org.apache.avro.SystemLimitException
- MAX_FIELD_PARAMETER_UNIT_COUNT - Static variable in class org.apache.avro.compiler.specific.SpecificCompiler
- MAX_STRING_LENGTH_PROPERTY - Static variable in exception class org.apache.avro.SystemLimitException
- 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.
- mergedWith(SchemaCompatibility.SchemaCompatibilityResult) - Method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
-
Merges the current
SchemaCompatibilityResult
with the supplied result into a new instance, combining the list ofIncompatibility Incompatibilities
and regressing to theSchemaCompatibilityType#INCOMPATIBLE INCOMPATIBLE
state if any incompatibilities are encountered. - messageDeclaration - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- messageDeclaration() - Method in class org.apache.avro.idl.IdlParser
- messageDeclaration() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- messageDeclaration(int) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- MessageDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- MessageDecoder<D> - Interface in org.apache.avro.message
-
Deserializes a single datum from a ByteBuffer, byte array, or InputStream.
- MessageDecoder.BaseDecoder<D> - Class in org.apache.avro.message
-
Base class for
MessageEncoder
implementations that provides default implementations for most of theDatumEncoder
API. - MessageEncoder<D> - Interface in org.apache.avro.message
-
Serializes an individual datum as a ByteBuffer or to an OutputStream.
- messages - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- 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> - 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 SequenceFile.Metadata field for the Avro key writer schema.
- METADATA_FIELD_VALUE_SCHEMA - Static variable in class org.apache.avro.hadoop.io.AvroSequenceFile
-
The SequenceFile.Metadata field for the Avro value writer schema.
- MISSING_ENUM_SYMBOLS - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaIncompatibilityType
- MISSING_REQUIRED_FIELD - Enum constant in enum org.apache.avro.Resolver.ErrorAction.ErrorType
-
Use when matching two records and the reader has a field with no default value and that field is missing in the writer..
- MISSING_UNION_BRANCH - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaIncompatibilityType
- MissingSchemaException - Exception Class in org.apache.avro.message
-
Exception thrown by a
MessageDecoder
when the message is encoded using an unknownSchema
. - MissingSchemaException(String) - Constructor for exception class org.apache.avro.message.MissingSchemaException
- modeNames - Static variable in class org.apache.avro.idl.IdlLexer
- msg - Variable in class org.apache.avro.io.parsing.Symbol.ErrorAction
- MultiLineComment - Static variable in class org.apache.avro.idl.IdlLexer
- MultiLineComment - Static variable in class org.apache.avro.idl.IdlParser
- mutualReadStrategy() - Method in class org.apache.avro.SchemaValidatorBuilder
-
Use a strategy that validates that a schema can read existing schema(s), and vice-versa, according to the Avro default schema resolution.
N
- name - Variable in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- name - Variable in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- name - Variable in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- name - Variable in class org.apache.avro.idl.IdlParser.JsonPairContext
- name - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- name - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- name - Variable in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- name - Variable in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- 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.
- NAME_MISMATCH - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaIncompatibilityType
- NamedBuilder(SchemaBuilder.NameContext, String) - Constructor for class org.apache.avro.SchemaBuilder.NamedBuilder
- namedSchemaDeclaration - Variable in class org.apache.avro.idl.IdlParser.IdlFileContext
- namedSchemaDeclaration - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- namedSchemaDeclaration() - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- namedSchemaDeclaration() - Method in class org.apache.avro.idl.IdlParser
- namedSchemaDeclaration() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- namedSchemaDeclaration(int) - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- namedSchemaDeclaration(int) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- NamedSchemaDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.NamedSchemaDeclarationContext
- namedSchemas - Variable in class org.apache.avro.idl.IdlParser.IdlFileContext
- namedSchemas - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- Named Types - Search tag in class org.apache.avro.SchemaBuilder
- Section
- names - Variable in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
- NAMES_DONT_MATCH - Enum constant in enum org.apache.avro.Resolver.ErrorAction.ErrorType
-
Use when Schema types match but, in the case of record, enum, or fixed, the names don't match.
- namespace - Variable in class org.apache.avro.idl.IdlParser.IdlFileContext
- namespace - Variable in class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- namespace(String) - Method in class org.apache.avro.SchemaBuilder.NamespacedBuilder
-
Set the namespace of this type.
- Namespace - Static variable in class org.apache.avro.idl.IdlLexer
- Namespace - Static variable in class org.apache.avro.idl.IdlParser
- Namespace() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Namespace() - Method in class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- NamespacedBuilder(SchemaBuilder.Completion<R>, SchemaBuilder.NameContext, String) - Constructor for class org.apache.avro.SchemaBuilder.NamespacedBuilder
- namespaceDeclaration() - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- namespaceDeclaration() - Method in class org.apache.avro.idl.IdlParser
- NamespaceDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- NameValidator - Interface in org.apache.avro
- NameValidator.Result - Class in org.apache.avro
- Nested Types - Search tag in class org.apache.avro.SchemaBuilder
- Section
- NETTY_CONNECT_TIMEOUT_OPTION - Static variable in class org.apache.avro.ipc.netty.NettyTransceiver
- NETTY_KEEPALIVE_OPTION - Static variable in class org.apache.avro.ipc.netty.NettyTransceiver
- NETTY_TCP_NODELAY_OPTION - Static variable in class org.apache.avro.ipc.netty.NettyTransceiver
- NettyClientAvroHandler() - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver.NettyClientAvroHandler
- NettyDataPack() - Constructor for class org.apache.avro.ipc.netty.NettyTransportCodec.NettyDataPack
- NettyDataPack(int, List<ByteBuffer>) - Constructor for class org.apache.avro.ipc.netty.NettyTransportCodec.NettyDataPack
- NettyFrameDecoder() - Constructor for class org.apache.avro.ipc.netty.NettyTransportCodec.NettyFrameDecoder
- NettyFrameEncoder() - Constructor for class org.apache.avro.ipc.netty.NettyTransportCodec.NettyFrameEncoder
- NettyServer - Class in org.apache.avro.ipc.netty
-
A Netty-based RPC
Server
implementation. - NettyServer(Responder, InetSocketAddress) - Constructor for class org.apache.avro.ipc.netty.NettyServer
- NettyServer(Responder, InetSocketAddress, Consumer<SocketChannel>) - Constructor for class org.apache.avro.ipc.netty.NettyServer
- NettyServer(Responder, InetSocketAddress, Consumer<SocketChannel>, Consumer<ServerBootstrap>) - Constructor for class org.apache.avro.ipc.netty.NettyServer
- NettyServer(Responder, InetSocketAddress, Consumer<SocketChannel>, Consumer<ServerBootstrap>, EventLoopGroup, EventLoopGroup, EventLoopGroup) - Constructor for class org.apache.avro.ipc.netty.NettyServer
- NettyTransceiver - Class in org.apache.avro.ipc.netty
-
A Netty-based
Transceiver
implementation. - NettyTransceiver(InetSocketAddress) - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver
-
Creates a NettyTransceiver, and attempts to connect to the given address.
- NettyTransceiver(InetSocketAddress, Integer) - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver
-
Creates a NettyTransceiver, and attempts to connect to the given address.
- NettyTransceiver(InetSocketAddress, Integer, Consumer<SocketChannel>) - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver
-
Creates a NettyTransceiver, and attempts to connect to the given address.
- NettyTransceiver(InetSocketAddress, Integer, Consumer<SocketChannel>, Consumer<Bootstrap>) - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver
-
Creates a NettyTransceiver, and attempts to connect to the given address.
- NettyTransceiver(InetSocketAddress, Consumer<SocketChannel>) - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver
-
Creates a NettyTransceiver, and attempts to connect to the given address.
- NettyTransceiver.NettyClientAvroHandler - Class in org.apache.avro.ipc.netty
-
Avro client handler for the Netty transport
- NettyTransceiver.NettyTransceiverThreadFactory - Class in org.apache.avro.ipc.netty
-
Creates threads with unique names based on a specified name prefix.
- NettyTransceiver.WriteFutureListener - Class in org.apache.avro.ipc.netty
-
A ChannelFutureListener for channel write operations that notifies a
Callback
if an error occurs while writing to the channel. - NettyTransceiverThreadFactory(String) - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver.NettyTransceiverThreadFactory
-
Creates a NettyTransceiverThreadFactory that creates threads with the specified name.
- NettyTransportCodec - Class in org.apache.avro.ipc.netty
-
Data structure, encoder and decoder classes for the Netty transport.
- NettyTransportCodec() - Constructor for class org.apache.avro.ipc.netty.NettyTransportCodec
- NettyTransportCodec.NettyDataPack - Class in org.apache.avro.ipc.netty
-
Transport protocol data structure when using Netty.
- NettyTransportCodec.NettyFrameDecoder - Class in org.apache.avro.ipc.netty
-
Protocol decoder which converts Netty's ChannelBuffer to NettyDataPack which contains a List<ByteBuffer> needed by Avro Responder.
- NettyTransportCodec.NettyFrameEncoder - Class in org.apache.avro.ipc.netty
-
Protocol encoder which converts NettyDataPack which contains the Responder's output List<ByteBuffer> to ChannelBuffer needed by Netty.
- NEVER - Enum constant in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Restructure
- NEW - Enum constant in enum org.apache.avro.io.FastReaderBuilder.RecordReader.Stage
- newArray(Object, int, Schema) - Method in class org.apache.avro.generic.GenericData
- 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() - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Creates a new HandshakeResponse RecordBuilder.
- newBuilder(HandshakeRequest) - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Creates a new HandshakeRequest RecordBuilder by copying an existing HandshakeRequest instance.
- newBuilder(HandshakeRequest.Builder) - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Creates a new HandshakeRequest 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(HandshakeResponse.Builder) - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Creates a new HandshakeResponse RecordBuilder by copying an existing Builder.
- newDecoder(byte[]) - Method in class org.apache.avro.perf.test.BasicState
- newEncoder(boolean, OutputStream) - Method in class org.apache.avro.perf.test.BasicState
- newEncoder(int, OutputStream) - Method in class org.apache.avro.perf.test.BasicState
- newInstance(Class, Schema) - Static method in class org.apache.avro.specific.SpecificData
-
Create an instance of a class.
- newInstance(Object, Schema) - Method in interface org.apache.avro.generic.GenericData.InstanceSupplier
- newInstanceFromString(Class, String) - Method in class org.apache.avro.generic.GenericDatumReader
- newMap(Object, int) - Method in class org.apache.avro.generic.GenericData
-
Called to create new array instances.
- 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.reflect.ReflectData
- 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.netty.NettyTransceiver.NettyTransceiverThreadFactory
- next() - Method in class org.apache.avro.file.DataFileReader12
- next() - Method in class org.apache.avro.file.DataFileStream
-
Read the next datum in the file.
- next() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
- next() - 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
- next(D) - Method in class org.apache.avro.file.DataFileReader12
-
Return 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(AvroWrapper<T>, NullWritable) - Method in class org.apache.avro.mapred.AvroRecordReader
- next(Pair<K, V>) - Method in class org.apache.avro.mapred.SequenceFileReader
- nextBlock() - Method in class org.apache.avro.file.DataFileStream
-
Expert: Return the next block in the file, as binary-encoded data.
- 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.
- NO_MATCHING_BRANCH - Enum constant in enum org.apache.avro.Resolver.ErrorAction.ErrorType
-
Use when matching a reader's union against a non-union and can't find a branch that matches.
- NO_VALIDATION - Static variable in interface org.apache.avro.NameValidator
- noAdjustments - Variable in class org.apache.avro.io.parsing.Symbol.EnumAdjustAction
- noAdjustmentsNeeded - Variable in class org.apache.avro.Resolver.EnumAdjust
- 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.
- NonCopyingByteArrayOutputStream - Class in org.apache.avro.util
-
Utility to make data written to an
ByteArrayOutputStream
directly available as aByteBuffer
. - NonCopyingByteArrayOutputStream(int) - Constructor for class org.apache.avro.util.NonCopyingByteArrayOutputStream
-
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
- NONE - Enum constant in enum org.apache.avro.ipc.HandshakeMatch
- noReorder - Variable in class org.apache.avro.io.parsing.Symbol.FieldOrderAction
- noReorder() - Method in class org.apache.avro.Resolver.RecordAdjust
-
Returns true iff
i == readerOrder[i].pos()
for all indicesi
. - Notes for implementers: - Search tag in org.apache.avro.FormattedSchemaParser.parse(ParseContext, URI, CharSequence)
- Section
- Notes for implementers: - Search tag in org.apache.avro.FormattedSchemaParser.parse(ParseContext, URI, CharSequence)
- Section
- Notes for implementers: - Search tag in org.apache.avro.FormattedSchemaParser.parse(ParseContext, URI, CharSequence)
- Section
- notValidatingDefaults() - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
-
Skip field default value validation during
SchemaBuilder.FieldBuilder.completeField(Schema, JsonNode)
} - npe(NullPointerException, String) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Helper method for adding a message to an NPE .
- Null - Static variable in class org.apache.avro.idl.IdlLexer
- Null - Static variable in class org.apache.avro.idl.IdlParser
- Null() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Null() - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- Null() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- NULL - Enum constant in enum org.apache.avro.Schema.Type
- NULL - Enum constant in enum org.apache.trevni.ValueType
- 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
- NULL_DEFAULT_VALUE - Static variable in class org.apache.avro.Schema.Field
-
For Schema unions with a "null" type as the first entry, this can be used to specify that the default for the union is null.
- NULL_VALUE - Static variable in class org.apache.avro.JsonProperties
-
A value representing a JSON
null
. - 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
- Nullable - Annotation Type in org.apache.avro.reflect
-
Declares that null is a valid value for a Java type.
- 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.
- 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.
- 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.
- 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.
- 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.
- 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.
- nullableType() - Method in class org.apache.avro.idl.IdlParser
- nullableType() - Method in class org.apache.avro.idl.IdlParser.PlainTypeContext
- NullableTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.NullableTypeContext
- 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.
- NullWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.NullWritableConverter
-
Constructor.
- numCalls - Variable in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
O
- ObjectReader() - Constructor for class org.apache.avro.data.Json.ObjectReader
- ObjectWriter() - Constructor for class org.apache.avro.data.Json.ObjectWriter
- of(long, long, long) - Static method in class org.apache.avro.util.TimePeriod
-
Create a TimePeriod from a number of months, days and milliseconds
- OK - Static variable in interface org.apache.avro.NameValidator
- oneway - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- Oneway - Static variable in class org.apache.avro.idl.IdlLexer
- Oneway - Static variable in class org.apache.avro.idl.IdlParser
- Oneway() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Oneway() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- 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.netty.NettyTransceiver.WriteFutureListener
- optional - Variable in class org.apache.avro.idl.IdlParser.NullableTypeContext
- 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.
- 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.
- 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.
- 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.
- optionalGettersForNullableFieldsOnly - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
The optionalGettersForNullableFieldsOnly parameter works in conjunction with gettersReturnOptional option.
- 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.
- 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.
- 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.
- Options() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
- Options() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
- Options() - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
- Options() - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Creates a new
Options
instance with default values. - 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 descending 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.avro_maven_plugin - package org.apache.avro.avro_maven_plugin
- org.apache.avro.compiler.schema - package org.apache.avro.compiler.schema
- 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.grpc - package org.apache.avro.grpc
- 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.idl - package org.apache.avro.idl
- 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.jetty - package org.apache.avro.ipc.jetty
- org.apache.avro.ipc.netty - package org.apache.avro.ipc.netty
- 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.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.message - package org.apache.avro.message
- org.apache.avro.mojo - package org.apache.avro.mojo
- org.apache.avro.path - package org.apache.avro.path
-
Interfaces and base classes for AvroPath.
- org.apache.avro.perf - package org.apache.avro.perf
- org.apache.avro.perf.test - package org.apache.avro.perf.test
- org.apache.avro.perf.test.basic - package org.apache.avro.perf.test.basic
- org.apache.avro.perf.test.basic.jmh_generated - package org.apache.avro.perf.test.basic.jmh_generated
- org.apache.avro.perf.test.generic - package org.apache.avro.perf.test.generic
- org.apache.avro.perf.test.generic.jmh_generated - package org.apache.avro.perf.test.generic.jmh_generated
- org.apache.avro.perf.test.record - package org.apache.avro.perf.test.record
- org.apache.avro.perf.test.record.jmh_generated - package org.apache.avro.perf.test.record.jmh_generated
- org.apache.avro.perf.test.reflect - package org.apache.avro.perf.test.reflect
- org.apache.avro.perf.test.reflect.jmh_generated - package org.apache.avro.perf.test.reflect.jmh_generated
- 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.avro.util.springframework - package org.apache.avro.util.springframework
- 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.DirectBinaryEncoder
- 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
-
Transmit outputs from a map or reduce task to parent.
- OutputProtocol.Callback - Interface in org.apache.avro.mapred.tether
-
Transmit outputs from a map or reduce task to parent.
P
- Pair<K,
V> - Class in org.apache.avro.mapred -
A key/value pair.
- Pair(CharSequence, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(CharSequence, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(CharSequence, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(CharSequence, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(CharSequence, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(CharSequence, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Double, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Double, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Double, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Double, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Double, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Double, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Float, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Float, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Float, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Float, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Float, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Float, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Integer, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Integer, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Integer, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Integer, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Integer, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Integer, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Long, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Long, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Long, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Long, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Long, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Long, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Object, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Object, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Object, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Object, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Object, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Object, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Void, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Void, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Void, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Void, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Void, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Void, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(ByteBuffer, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(ByteBuffer, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(ByteBuffer, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(ByteBuffer, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(ByteBuffer, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(ByteBuffer, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(K, Schema, V, Schema) - Constructor for class org.apache.avro.mapred.Pair
- Pair(GenericContainer, CharSequence) - Constructor for class org.apache.avro.mapred.Pair
- Pair(GenericContainer, Double) - Constructor for class org.apache.avro.mapred.Pair
- Pair(GenericContainer, Float) - 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, Object) - Constructor for class org.apache.avro.mapred.Pair
- Pair(GenericContainer, Void) - Constructor for class org.apache.avro.mapred.Pair
- Pair(GenericContainer, ByteBuffer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(GenericContainer, GenericContainer) - Constructor for class org.apache.avro.mapred.Pair
- Pair(Schema) - Constructor for class org.apache.avro.mapred.Pair
- parameter - Variable in class org.apache.avro.idl.IdlParser.FormalParameterContext
- parameterType - Variable in class org.apache.avro.idl.IdlParser.FormalParameterContext
- Params(File) - Constructor for class org.apache.trevni.avro.AvroColumnReader.Params
-
Construct reading from a file.
- Params(Input) - Constructor for class org.apache.trevni.avro.AvroColumnReader.Params
-
Construct reading from input.
- parse(File) - Static method in class org.apache.avro.Protocol
-
Read a protocol from a Json file.
- parse(File) - Static method in class org.apache.avro.Schema
-
Deprecated.use
SchemaParser
instead. - parse(File) - Method in class org.apache.avro.Schema.Parser
-
Parse a schema from the provided file.
- parse(File) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from a file.
- parse(File, Charset) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from a file written with a specific character set.
- parse(InputStream) - Method in class org.apache.avro.grpc.AvroRequestMarshaller
- parse(InputStream) - Method in class org.apache.avro.grpc.AvroResponseMarshaller
- parse(InputStream) - Method in class org.apache.avro.idl.IdlReader
-
Parse an IDL file from a stream.
- parse(InputStream) - Static method in class org.apache.avro.Protocol
-
Read a protocol from a Json stream.
- parse(InputStream) - Static method in class org.apache.avro.Schema
-
Deprecated.use
SchemaParser
instead. - parse(InputStream) - Method in class org.apache.avro.Schema.Parser
-
Parse a schema from the provided stream.
- parse(InputStream) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from an input stream.
- parse(InputStream, Charset) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from an input stream.
- parse(Reader) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from an input reader.
- parse(CharSequence) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from a string.
- parse(String) - Static method in class org.apache.avro.Protocol
-
Read a protocol from a Json string.
- parse(String) - Static method in class org.apache.avro.Schema
-
Deprecated.use
SchemaParser
instead. - parse(String) - Method in class org.apache.avro.Schema.Parser
-
Parse a schema from the provided string.
- parse(String, boolean) - Static method in class org.apache.avro.Schema
-
Deprecated.use
SchemaParser
instead. - parse(String, String...) - Static method in class org.apache.avro.Protocol
-
Read a protocol from one or more json strings
- parse(String, String...) - Method in class org.apache.avro.Schema.Parser
-
Read a schema from one or more json strings
- parse(URI, CharSequence) - Method in class org.apache.avro.idl.IdlReader
-
Parse an IDL file from a string, using the given directory for imports.
- parse(URI, Charset) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from a file written with a specific character set.
- parse(Path) - Method in class org.apache.avro.idl.IdlReader
- parse(Path) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from a file.
- parse(Path, Charset) - Method in class org.apache.avro.SchemaParser
-
Parse an Avro schema from a file written with a specific character set.
- parse(ParseContext, URI, CharSequence) - Method in interface org.apache.avro.FormattedSchemaParser
-
Parse schema definitions from a text based source.
- parse(ParseContext, URI, CharSequence) - Method in class org.apache.avro.idl.IdlSchemaParser
- parse(ParseContext, URI, CharSequence) - Method in class org.apache.avro.JsonSchemaParser
- ParseContext - Class in org.apache.avro
-
Class to define a name context, useful to reference schemata with.
- ParseContext() - Constructor for class org.apache.avro.ParseContext
-
Create a
ParseContext
for the default/null
namespace, using default name validation for new schemata. - ParseContext(NameValidator) - Constructor for class org.apache.avro.ParseContext
-
Create a
ParseContext
using the specified name validation for new schemata. - parsedNamedSchemas() - Method in interface org.apache.avro.SchemaParser.ParseResult
-
The list of named schemata that were parsed.
- parseInternal(String) - Method in class org.apache.avro.Schema.Parser
- parseInternal(String...) - Static method in class org.apache.avro.JsonSchemaParser
-
Parse a schema written in the internal (JSON) format without any validations.
- parseJson(String) - Static method in class org.apache.avro.data.Json
-
Parses a JSON string and converts it to the object model described in
JsonProperties
. - parseJsonToObject(String) - Static method in class org.apache.avro.Schema
-
Parses the specified json string to an object.
- parser - Variable in class org.apache.avro.io.ParsingDecoder
- parser - Variable in class org.apache.avro.io.ValidatingEncoder
- Parser - Class in org.apache.avro.io.parsing
-
Parser is the class that maintains the stack for parsing.
- Parser() - Constructor for class org.apache.avro.Schema.Parser
- Parser(Symbol, Parser.ActionHandler) - Constructor for class org.apache.avro.io.parsing.Parser
- Parser(NameValidator) - Constructor for class org.apache.avro.Schema.Parser
- Parser(ParseContext) - Constructor for class org.apache.avro.Schema.Parser
- 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
- ParsingDecoder(Symbol) - Constructor for class org.apache.avro.io.ParsingDecoder
- ParsingEncoder - Class in org.apache.avro.io
- 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. - Parsing tables for Avro - Search tag in package org.apache.avro.io.parsing
- Section
- 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
- 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
- PathElement - Interface in org.apache.avro.path
-
root interface for all pieces of an AvroPath expression
- PathPredicate - Interface in org.apache.avro.path
-
a predicate is a filter that restricts items selected by a
LocationStep
- PathTracingException<T> - Interface in org.apache.avro.path
-
interface for exceptions that can trace the AvroPath of an error
- PAYLOAD_SEGMENTER - Static variable in class org.apache.avro.ipc.stats.StatsPlugin
- 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
- peek() - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- peek() - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- peek() - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- peek() - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- peek() - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- 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
- Perf - Class in org.apache.avro.perf
-
Performance tests for various low level operations of Avro encoding and decoding.
- Perf() - Constructor for class org.apache.avro.perf.Perf
- plainType() - Method in class org.apache.avro.idl.IdlParser.FullTypeContext
- plainType() - Method in class org.apache.avro.idl.IdlParser
- plainType() - Method in class org.apache.avro.idl.IdlParser.ResultTypeContext
- PlainTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.PlainTypeContext
- pollForPurge() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.ReferenceManager
-
Return any reference that has been garbage collected and can be purged from the underlying structure or
null
if no references need purging. - 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.
- 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.
- PositionalPathPredicate - Interface in org.apache.avro.path
-
filters items by their context position
- precision - Variable in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- prepend(List<ByteBuffer>) - Method in class org.apache.avro.util.ByteBufferOutputStream
-
Prepend a list of ByteBuffers to this stream.
- previousSync() - Method in class org.apache.avro.file.DataFileReader
-
Return the last synchronization point before our current position.
- PrimitivesArrays - Class in org.apache.avro.generic
- PrimitivesArrays() - Constructor for class org.apache.avro.generic.PrimitivesArrays
- PrimitivesArrays.BooleanArray - Class in org.apache.avro.generic
- PrimitivesArrays.DoubleArray - Class in org.apache.avro.generic
- PrimitivesArrays.FloatArray - Class in org.apache.avro.generic
- PrimitivesArrays.IntArray - Class in org.apache.avro.generic
- PrimitivesArrays.LongArray - Class in org.apache.avro.generic
- primitiveType() - Method in class org.apache.avro.idl.IdlParser.NullableTypeContext
- primitiveType() - Method in class org.apache.avro.idl.IdlParser
- PrimitiveTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- Primitive Types - Search tag in class org.apache.avro.SchemaBuilder
- Section
- PRIVATE - Enum constant in enum org.apache.avro.compiler.specific.SpecificCompiler.FieldVisibility
- 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.
- project - Variable in class org.apache.avro.mojo.InduceMojo
-
The current Maven project.
- PROMOTE - Enum constant in enum org.apache.avro.Resolver.Action.Type
- prop(String, Object) - Method in class org.apache.avro.SchemaBuilder.PropBuilder
-
Set name-value pair properties for this type or field.
- prop(String, String) - Method in class org.apache.avro.SchemaBuilder.PropBuilder
-
Set name-value pair properties for this type or field.
- PropBuilder() - Constructor for class org.apache.avro.SchemaBuilder.PropBuilder
- propsContainsKey(String) - Method in class org.apache.avro.JsonProperties
- 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(ProtobufData) - 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
- protocol - Variable in class org.apache.avro.idl.IdlParser.IdlFileContext
- Protocol - Class in org.apache.avro
-
A set of messages forming an application protocol.
- Protocol - Static variable in class org.apache.avro.idl.IdlLexer
- Protocol - Static variable in class org.apache.avro.idl.IdlParser
- Protocol(String, String) - Constructor for class org.apache.avro.Protocol
- Protocol(String, String, String) - Constructor for class org.apache.avro.Protocol
- Protocol(Protocol) - Constructor for class org.apache.avro.Protocol
-
Constructs a similar Protocol instance with the same
name
,doc
, andnamespace
as {code p} has. - Protocol() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Protocol() - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- Protocol() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- 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.Message - Class in org.apache.avro
-
A protocol message.
- protocolDeclaration() - Method in class org.apache.avro.idl.IdlParser.IdlFileContext
- protocolDeclaration() - Method in class org.apache.avro.idl.IdlParser
- protocolDeclarationBody() - Method in class org.apache.avro.idl.IdlParser
- protocolDeclarationBody() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- ProtocolDeclarationBodyContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- ProtocolDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- 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
- ProtoConversions - Class in org.apache.avro.protobuf
- ProtoConversions() - Constructor for class org.apache.avro.protobuf.ProtoConversions
- ProtoConversions.TimestampMicrosConversion - Class in org.apache.avro.protobuf
- ProtoConversions.TimestampMillisConversion - Class in org.apache.avro.protobuf
- ProtoConversions.TimestampNanosConversion - Class in org.apache.avro.protobuf
- prune() - Method in interface org.apache.avro.generic.GenericArray
-
clean up reusable objects from array (if reset didn't already)
- prune() - Method in class org.apache.avro.generic.GenericData.Array
- PUBLIC - Enum constant in enum org.apache.avro.compiler.specific.SpecificCompiler.FieldVisibility
- publicFields() - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- purgeUnreferencedEntries() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
-
Remove any entries that have been garbage collected and are no longer referenced.
- 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(int, Object) - Method in class org.apache.avro.generic.GenericData.Record
- 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.mapred.Pair
- put(int, Object) - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- put(String, 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(String, Object) - Method in class org.apache.avro.specific.SpecificRecordBase
- put(K, V) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- put(K, V) - Method in class org.apache.avro.util.WeakIdentityHashMap
- put(Schema) - Method in class org.apache.avro.ParseContext
-
Put the schema into this context.
- putAll(Map) - Method in class org.apache.avro.util.WeakIdentityHashMap
- putAll(JsonProperties) - Method in class org.apache.avro.JsonProperties
- putIfAbsent(K, V) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
Q
- QuestionMark - Static variable in class org.apache.avro.idl.IdlLexer
- QuestionMark - Static variable in class org.apache.avro.idl.IdlParser
- QuestionMark() - Method in class org.apache.avro.idl.IdlParser.NullableTypeContext
R
- RandomData - Class in org.apache.avro.util
-
Generates schema data as Java objects with random values.
- RandomData(GenericData, Schema, int) - Constructor for class org.apache.avro.util.RandomData
- RandomData(GenericData, Schema, int, boolean) - Constructor for class org.apache.avro.util.RandomData
- RandomData(GenericData, Schema, int, long) - Constructor for class org.apache.avro.util.RandomData
- RandomData(GenericData, Schema, int, long, boolean) - Constructor for class org.apache.avro.util.RandomData
- RandomData(Schema, int) - Constructor for class org.apache.avro.util.RandomData
- RandomData(Schema, int, boolean) - Constructor for class org.apache.avro.util.RandomData
- RandomData(Schema, int, long) - Constructor for class org.apache.avro.util.RandomData
- RandomData(Schema, int, long, boolean) - Constructor for class org.apache.avro.util.RandomData
- RawMessageDecoder<D> - Class in org.apache.avro.message
-
A
MessageDecoder
that deserializes from raw datum bytes. - RawMessageDecoder(GenericData, Schema) - Constructor for class org.apache.avro.message.RawMessageDecoder
-
Creates a new
RawMessageDecoder
that uses the givendata model
to construct datum instances described by theschema
. - RawMessageDecoder(GenericData, Schema, Schema) - Constructor for class org.apache.avro.message.RawMessageDecoder
-
Creates a new
RawMessageDecoder
that uses the givendata model
to construct datum instances described by thereadSchema
. - RawMessageEncoder<D> - Class in org.apache.avro.message
-
A
MessageEncoder
that encodes only a datum's bytes, without additional information (such as a schema fingerprint). - RawMessageEncoder(GenericData, Schema) - Constructor for class org.apache.avro.message.RawMessageEncoder
-
Creates a new
RawMessageEncoder
that uses the givendata model
to deconstruct datum instances described by theschema
. - RawMessageEncoder(GenericData, Schema, boolean) - Constructor for class org.apache.avro.message.RawMessageEncoder
-
Creates a new
RawMessageEncoder
that uses the givendata model
to deconstruct datum instances described by theschema
. - RBrace - Static variable in class org.apache.avro.idl.IdlLexer
- RBrace - Static variable in class org.apache.avro.idl.IdlParser
- RBrace() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- RBrace() - Method in class org.apache.avro.idl.IdlParser.JsonObjectContext
- RBrace() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationBodyContext
- RBrace() - Method in class org.apache.avro.idl.IdlParser.RecordBodyContext
- RBrace() - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- RBracket - Static variable in class org.apache.avro.idl.IdlLexer
- RBracket - Static variable in class org.apache.avro.idl.IdlParser
- RBracket() - Method in class org.apache.avro.idl.IdlParser.JsonArrayContext
- read() - Method in class org.apache.avro.grpc.AvroInputStream
- read() - Method in class org.apache.avro.util.ByteBufferInputStream
- read() - Method in class org.apache.avro.util.ReusableByteBufferInputStream
- read(byte[], int, int) - Method in interface org.apache.avro.file.SeekableInput
-
Equivalent to
InputStream.read(byte[],int,int)
. - read(byte[], int, int) - Method in class org.apache.avro.grpc.AvroInputStream
- read(byte[], int, int) - Method in class org.apache.avro.mapred.FsInput
- read(byte[], int, int) - Method in class org.apache.avro.util.ByteBufferInputStream
- read(byte[], int, int) - Method in class org.apache.avro.util.ReusableByteBufferInputStream
- 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
- read(D, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
- read(D, Decoder) - Method in interface org.apache.avro.io.DatumReader
-
Read a datum.
- read(Object, Decoder) - Method in class org.apache.avro.data.Json.ObjectReader
- read(Object, Decoder) - Method in interface org.apache.avro.io.FastReaderBuilder.FieldReader
- read(Object, Decoder) - Method in class org.apache.avro.io.FastReaderBuilder.MapReader
- read(Object, Decoder) - Method in class org.apache.avro.io.FastReaderBuilder.RecordReader
- read(Object, Decoder) - Method in class org.apache.avro.reflect.CustomEncoding
- read(Object, Decoder) - Method in class org.apache.avro.reflect.DateAsLongEncoding
- read(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read data.
- readAllBytes(InputStream, Charset) - Static method in class org.apache.avro.util.UtfTextUtils
-
Reads the specified input stream as text.
- readAllChars(Reader) - Static method in class org.apache.avro.util.UtfTextUtils
- 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.netty.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)
. - readBytes(Object, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read byte arrays.
- readBytes(Object, Decoder) - Method in class org.apache.avro.protobuf.ProtobufDatumReader
- readBytes(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read byte arrays.
- readBytes(Object, Schema, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
- 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)
. if old is not null and has sufficient capacity to take in the bytes being read, the bytes are returned in old. - readBytes(ByteBuffer) - Method in class org.apache.avro.io.JsonDecoder
- readBytes(ByteBuffer) - Method in class org.apache.avro.io.ResolvingDecoder
- readBytes(ByteBuffer) - Method in class org.apache.avro.io.ValidatingDecoder
- 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() - 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
- readEnum(Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read an enum value.
- reader - Variable in class org.apache.avro.io.parsing.Symbol.ResolvingAction
- reader - Variable in class org.apache.avro.Resolver.Action
- Reader(SortedKeyValueFile.Reader.Options) - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
-
Constructs a reader.
- Reader(AvroSequenceFile.Reader.Options) - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Reader
-
Creates a new
Reader
from a SequenceFile that supports Avro data. - READER_FIELD_MISSING_DEFAULT_VALUE - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaIncompatibilityType
- READER_UNION - Enum constant in enum org.apache.avro.Resolver.Action.Type
- READER_WRITER_COMPATIBLE_MESSAGE - Static variable in class org.apache.avro.SchemaCompatibility
-
Message to annotate reader/writer schema pairs that are compatible.
- readerOrder - Variable in class org.apache.avro.Resolver.RecordAdjust
-
Contains (all of) the reader's fields.
- readError(Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
-
Deprecated.
- readError(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.generic.GenericRequestor
- 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
- ReaderUnion(Schema, Schema, GenericData, int, Resolver.Action) - Constructor for class org.apache.avro.Resolver.ReaderUnion
- readExternal(ObjectInput) - Method in class org.apache.avro.ipc.HandshakeRequest
- readExternal(ObjectInput) - Method in class org.apache.avro.ipc.HandshakeResponse
- readExternal(ObjectInput) - Method in class org.apache.avro.ipc.MD5
- readExternal(ObjectInput) - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- readExternal(ObjectInput) - Method in class org.apache.avro.specific.SpecificFixed
- readExternal(ObjectInput) - Method in class org.apache.avro.specific.SpecificRecordBase
- readExternal(ObjectInput) - Method in class org.apache.avro.util.Utf8
- 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
- readField(Object, Schema.Field, Object, ResolvingDecoder, Object) - Method in class org.apache.avro.specific.SpecificDatumReader
- 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.
- readFieldOrderIfDiff() - Method in class org.apache.avro.io.ResolvingDecoder
-
Same as
ResolvingDecoder.readFieldOrder()
except that it returns null if there was no reordering of fields, i.e., if the correct thing for the reader to do is to read (all) of its fields in the order specified by its own schema (useful for optimizations). - 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.BinaryDecoder
- readFixed(byte[], int, int) - Method in class org.apache.avro.io.Decoder
-
Reads fixed sized binary object.
- readFixed(byte[], int, int) - Method in class org.apache.avro.io.JsonDecoder
- readFixed(byte[], int, int) - Method in class org.apache.avro.io.ValidatingDecoder
- readFixed(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read a fixed value.
- 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() - 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.generic.GenericDatumReader
-
Called to read integers.
- 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
-
Called by the default implementation of
GenericDatumReader.readMap(java.lang.Object, org.apache.avro.Schema, org.apache.avro.io.ResolvingDecoder)
to read a key value. - 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
- readRecord(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.specific.SpecificDatumReader
- 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, Decoder) - Method in class org.apache.avro.ipc.Requestor
-
Deprecated.
- readResponse(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.generic.GenericRequestor
- 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() - Method in class org.apache.avro.io.BinaryDecoder
- readString() - 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.JsonDecoder
- readString() - Method in class org.apache.avro.io.ResolvingDecoder
- readString() - Method in class org.apache.avro.io.ValidatingDecoder
- readString(Object, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read strings.
- readString(Object, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
- readString(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read strings.
- readString(Utf8) - 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(Utf8) - Method in class org.apache.avro.io.JsonDecoder
- readString(Utf8) - Method in class org.apache.avro.io.ResolvingDecoder
- readString(Utf8) - Method in class org.apache.avro.io.ValidatingDecoder
- readWithConversion(Object, Schema, LogicalType, Conversion<?>, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
- readWithoutConversion(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
- 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(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 - Static variable in class org.apache.avro.idl.IdlLexer
- Record - Static variable in class org.apache.avro.idl.IdlParser
- Record(GenericData.Record, boolean) - Constructor for class org.apache.avro.generic.GenericData.Record
- Record(Schema) - Constructor for class org.apache.avro.generic.GenericData.Record
- Record() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Record() - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- RECORD - Enum constant in enum org.apache.avro.Resolver.Action.Type
- RECORD - Enum constant in enum org.apache.avro.Schema.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
- recordBody() - Method in class org.apache.avro.idl.IdlParser
- recordBody() - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- RecordBodyContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.RecordBodyContext
- RecordBuilder<T> - Interface in org.apache.avro.data
-
Interface for record builders
- RecordBuilderBase<T> - Class in org.apache.avro.data
-
Abstract base class for RecordBuilder implementations.
- RecordBuilderBase(RecordBuilderBase<T>, GenericData) - Constructor for class org.apache.avro.data.RecordBuilderBase
-
RecordBuilderBase copy constructor.
- RecordBuilderBase(Schema, GenericData) - Constructor for class org.apache.avro.data.RecordBuilderBase
-
Creates a RecordBuilderBase for building records of the given type.
- RecordCountTool - Class in org.apache.avro.tool
-
Counts the records in avro files or folders
- RecordCountTool() - Constructor for class org.apache.avro.tool.RecordCountTool
- recordDeclaration() - Method in class org.apache.avro.idl.IdlParser.NamedSchemaDeclarationContext
- recordDeclaration() - Method in class org.apache.avro.idl.IdlParser
- RecordDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- recordDefault(GenericRecord) - Method in class org.apache.avro.SchemaBuilder.RecordDefault
-
Completes this field with the default value provided, cannot be null
- RecordReader() - Constructor for class org.apache.avro.io.FastReaderBuilder.RecordReader
- RecordTest - Class in org.apache.avro.perf.test.record
- RecordTest() - Constructor for class org.apache.avro.perf.test.record.RecordTest
- RecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
- RecordTest_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType
- RecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B1
- RecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- RecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B3
- RecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType
- RecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B1
- RecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- RecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B3
- RecordTest.TestStateDecode - Class in org.apache.avro.perf.test.record
- recordType - Variable in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- RecordWithDefaultTest - Class in org.apache.avro.perf.test.record
- RecordWithDefaultTest() - Constructor for class org.apache.avro.perf.test.record.RecordWithDefaultTest
- RecordWithDefaultTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
- RecordWithDefaultTest_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType
- RecordWithDefaultTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B1
- RecordWithDefaultTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- RecordWithDefaultTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B3
- RecordWithDefaultTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType
- RecordWithDefaultTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B1
- RecordWithDefaultTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- RecordWithDefaultTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithDefaultTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B3
- RecordWithDefaultTest.TestStateDecode - Class in org.apache.avro.perf.test.record
- RecordWithOutOfOrderTest - Class in org.apache.avro.perf.test.record
- RecordWithOutOfOrderTest() - Constructor for class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest
- RecordWithOutOfOrderTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
- RecordWithOutOfOrderTest_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType
- RecordWithOutOfOrderTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B1
- RecordWithOutOfOrderTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- RecordWithOutOfOrderTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B3
- RecordWithOutOfOrderTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B1
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B3
- RecordWithOutOfOrderTest.TestStateDecode - Class in org.apache.avro.perf.test.record
- RecordWithPromotionTest - Class in org.apache.avro.perf.test.record
- RecordWithPromotionTest() - Constructor for class org.apache.avro.perf.test.record.RecordWithPromotionTest
- RecordWithPromotionTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
- RecordWithPromotionTest_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType
- RecordWithPromotionTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B1
- RecordWithPromotionTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- RecordWithPromotionTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B3
- RecordWithPromotionTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType
- RecordWithPromotionTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B1
- RecordWithPromotionTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- RecordWithPromotionTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- RecordWithPromotionTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B3
- RecordWithPromotionTest.TestStateDecode - Class in org.apache.avro.perf.test.record
- RecordWriterFactory() - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat.RecordWriterFactory
- RECURSION_IN_PROGRESS - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaCompatibilityType
-
Used internally to tag a reader/writer schema pair and prevent recursion.
- recursionInProgress() - Static method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
-
Returns a details object representing a state indicating that recursion is in progress.
- 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.
- REDUCE - Enum constant in enum org.apache.avro.mapred.tether.TaskType
- ReferenceManager() - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.ReferenceManager
- referenceName - Variable in class org.apache.avro.idl.IdlParser.NullableTypeContext
- ReflectBigRecordTest - Class in org.apache.avro.perf.test.reflect
- ReflectBigRecordTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectBigRecordTest
- ReflectBigRecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
- ReflectBigRecordTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_encode_jmhTest
- ReflectBigRecordTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType
- ReflectBigRecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B1
- ReflectBigRecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- ReflectBigRecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B3
- ReflectBigRecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType
- ReflectBigRecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B1
- ReflectBigRecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- ReflectBigRecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B3
- ReflectBigRecordTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType
- ReflectBigRecordTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B1
- ReflectBigRecordTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- ReflectBigRecordTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectBigRecordTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B3
- ReflectBigRecordTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectBigRecordTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- 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. - 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(ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
-
Construct given a
ReflectData
. - 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.
- 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(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
- ReflectDoubleArrayTest - Class in org.apache.avro.perf.test.reflect
- ReflectDoubleArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest
- ReflectDoubleArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
- ReflectDoubleArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_encode_jmhTest
- ReflectDoubleArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType
- ReflectDoubleArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B1
- ReflectDoubleArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- ReflectDoubleArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B3
- ReflectDoubleArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B1
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B3
- ReflectDoubleArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B1
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B3
- ReflectDoubleArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectDoubleArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectFloatArrayTest - Class in org.apache.avro.perf.test.reflect
- ReflectFloatArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest
- ReflectFloatArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
- ReflectFloatArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_encode_jmhTest
- ReflectFloatArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType
- ReflectFloatArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B1
- ReflectFloatArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- ReflectFloatArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B3
- ReflectFloatArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType
- ReflectFloatArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B1
- ReflectFloatArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- ReflectFloatArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B3
- ReflectFloatArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType
- ReflectFloatArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B1
- ReflectFloatArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- ReflectFloatArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectFloatArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B3
- ReflectFloatArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectFloatArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectIntArrayTest - Class in org.apache.avro.perf.test.reflect
- ReflectIntArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectIntArrayTest
- ReflectIntArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
- ReflectIntArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_encode_jmhTest
- ReflectIntArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType
- ReflectIntArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B1
- ReflectIntArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- ReflectIntArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B3
- ReflectIntArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType
- ReflectIntArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B1
- ReflectIntArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- ReflectIntArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B3
- ReflectIntArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType
- ReflectIntArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B1
- ReflectIntArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- ReflectIntArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectIntArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B3
- ReflectIntArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectIntArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectionUtil - Class in org.apache.avro.reflect
-
A few utility methods for using @link{java.misc.Unsafe}, mostly for private use.
- ReflectLargeFloatArrayBlockedTest - Class in org.apache.avro.perf.test.reflect
-
Uses a larger array size than
ReflectFloatArrayTest
. - ReflectLargeFloatArrayBlockedTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest
- ReflectLargeFloatArrayBlockedTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
- ReflectLargeFloatArrayBlockedTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
- ReflectLargeFloatArrayBlockedTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType
- ReflectLargeFloatArrayBlockedTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B1
- ReflectLargeFloatArrayBlockedTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- ReflectLargeFloatArrayBlockedTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B3
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B1
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B3
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B1
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B3
- ReflectLargeFloatArrayBlockedTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectLargeFloatArrayBlockedTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectLargeFloatArrayTest - Class in org.apache.avro.perf.test.reflect
-
Uses a larger array size than
ReflectFloatArrayTest
. - ReflectLargeFloatArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest
- ReflectLargeFloatArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
- ReflectLargeFloatArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_encode_jmhTest
- ReflectLargeFloatArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType
- ReflectLargeFloatArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B1
- ReflectLargeFloatArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- ReflectLargeFloatArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B3
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B1
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B3
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B1
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B3
- ReflectLargeFloatArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectLargeFloatArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectLongArrayTest - Class in org.apache.avro.perf.test.reflect
- ReflectLongArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLongArrayTest
- ReflectLongArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
- ReflectLongArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_encode_jmhTest
- ReflectLongArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType
- ReflectLongArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B1
- ReflectLongArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- ReflectLongArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B3
- ReflectLongArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType
- ReflectLongArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B1
- ReflectLongArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- ReflectLongArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B3
- ReflectLongArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType
- ReflectLongArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B1
- ReflectLongArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- ReflectLongArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectLongArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B3
- ReflectLongArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectLongArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectNestedFloatArrayTest - Class in org.apache.avro.perf.test.reflect
- ReflectNestedFloatArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest
- ReflectNestedFloatArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
- ReflectNestedFloatArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_encode_jmhTest
- ReflectNestedFloatArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType
- ReflectNestedFloatArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B1
- ReflectNestedFloatArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- ReflectNestedFloatArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B3
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B1
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B3
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B1
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B3
- ReflectNestedFloatArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectNestedFloatArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectNestedObjectArrayTest - Class in org.apache.avro.perf.test.reflect
- ReflectNestedObjectArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest
- ReflectNestedObjectArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
- ReflectNestedObjectArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_encode_jmhTest
- ReflectNestedObjectArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType
- ReflectNestedObjectArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B1
- ReflectNestedObjectArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- ReflectNestedObjectArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B3
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B1
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B3
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B1
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B3
- ReflectNestedObjectArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectNestedObjectArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- ReflectRecordTest - Class in org.apache.avro.perf.test.reflect
- ReflectRecordTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectRecordTest
- ReflectRecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
- ReflectRecordTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_encode_jmhTest
- ReflectRecordTest_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType
- ReflectRecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B1
- ReflectRecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- ReflectRecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B3
- ReflectRecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType
- ReflectRecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B1
- ReflectRecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- ReflectRecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B3
- ReflectRecordTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType
- ReflectRecordTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B1
- ReflectRecordTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- ReflectRecordTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.jmh_generated
- ReflectRecordTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B3
- ReflectRecordTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
- ReflectRecordTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
- 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(Class<?>, Transceiver, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
- ReflectRequestor(Protocol, Transceiver) - 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(Class, Object, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
- ReflectResponder(Protocol, Object) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
- ReflectResponder(Protocol, Object, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
- register(String, LogicalTypes.LogicalTypeFactory) - Static method in class org.apache.avro.LogicalTypes
-
Register a logical type.
- register(LogicalTypes.LogicalTypeFactory) - Static method in class org.apache.avro.LogicalTypes
-
Register a logical type.
- release() - Method in interface org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Reference
-
Release this entry and ensure that it will be returned from
ReferenceManager#pollForPurge()
. - Reminder on LL(1) parsing - Search tag in package org.apache.avro.io.parsing
- Section
- remove() - Method in class org.apache.avro.file.DataFileReader12
- remove() - Method in class org.apache.avro.file.DataFileStream
-
Not supported.
- remove() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
- remove() - Method in class org.apache.avro.mapred.SequenceFileReader
- remove() - Method in class org.apache.trevni.avro.AvroColumnReader
- remove() - Method in class org.apache.trevni.ColumnValues
- remove(int) - Method in class org.apache.avro.generic.GenericData.Array
- remove(int) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- remove(int) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- remove(int) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- remove(int) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- remove(int) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- remove(Object) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- remove(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
- remove(Object, Object) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- RenderableMessage(String) - Constructor for class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
- REPEATER - Enum constant in enum org.apache.avro.io.parsing.Symbol.Kind
-
non-terminal to represent the contents of an array or map
- replace(K, V) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- replace(K, V, V) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- 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.
- 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.
- RESERVED_WORD_ESCAPE_CHAR - Static variable in class org.apache.avro.specific.SpecificData
- RESERVED_WORDS - Static variable in class org.apache.avro.specific.SpecificData
-
Reserved words from https://docs.oracle.com/javase/specs/jls/se16/html/jls-3.html require mangling in order to be used in generated Java code.
- reset() - Method in interface org.apache.avro.generic.GenericArray
-
reset size counter of array to zero
- reset() - Method in class org.apache.avro.generic.GenericData.AbstractArray
- reset() - Method in class org.apache.avro.io.FastReaderBuilder.RecordReader
- reset() - Method in class org.apache.avro.io.parsing.Parser
- reset() - Method in class org.apache.avro.util.ByteBufferOutputStream
- reset() - Method in class org.apache.avro.util.ReusableByteBufferInputStream
- Resolution using action symbols - Search tag in package org.apache.avro.io.parsing
- Section
- resolve(Schema) - Method in class org.apache.avro.ParseContext
-
Resolve unresolved references in a schema that was parsed for this context using the types known to this context.
- resolve(SchemaParser.ParseResult) - Method in class org.apache.avro.SchemaParser
-
Deprecated.
- 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(Object, Decoder)
. - resolve(Schema, Schema) - Static method in class org.apache.avro.Resolver
-
Uses GenericData.get() for the data param.
- resolve(Schema, Schema, GenericData) - Static method in class org.apache.avro.Resolver.EnumAdjust
-
If writer and reader don't have same name, a
Resolver.ErrorAction.ErrorType.NAMES_DONT_MATCH
is returned, otherwise an appropriateResolver.EnumAdjust
is. - resolve(Schema, Schema, GenericData) - Static method in class org.apache.avro.Resolver.Promote
-
Return a promotion.
- resolve(Schema, Schema, GenericData) - Static method in class org.apache.avro.Resolver
-
Returns a
Resolver.Action
tree for resolving the writer schema writer and the reader schema reader. - resolve(Schema, Schema, GenericData, Map<Schema.SeenPair, Resolver.Action>) - Static method in class org.apache.avro.Resolver.ReaderUnion
-
Returns a
Resolver.ReaderUnion
action for resolving w and r, or anResolver.ErrorAction
if there is no branch in the reader that matches the writer. - resolve(Schema, Schema, GenericData, Map<Schema.SeenPair, Resolver.Action>) - Static method in class org.apache.avro.Resolver.WriterUnion
- resolveAllSchemas() - Method in class org.apache.avro.ParseContext
-
Resolve all (named) schemas that were parsed.
- Resolver - Class in org.apache.avro
-
Encapsulate schema-resolution logic in an easy-to-consume representation.
- Resolver() - Constructor for class org.apache.avro.Resolver
- Resolver.Action - Class in org.apache.avro
-
An abstract class for an action to be taken to resolve a writer's schema (found in public instance variable writer) against a reader's schema (in reader).
- Resolver.Action.Type - Enum in org.apache.avro
-
Helps us traverse faster.
- Resolver.Container - Class in org.apache.avro
-
Used for array and map schemas: the public instance variable elementAction contains the resolving action needed for the element type of an array or value top of a map.
- Resolver.DoNothing - Class in org.apache.avro
-
In this case, there's nothing to be done for resolution: the two schemas are effectively the same.
- Resolver.EnumAdjust - Class in org.apache.avro
-
Contains information needed to resolve enumerations.
- Resolver.ErrorAction - Class in org.apache.avro
-
In this case there is an error.
- Resolver.ErrorAction.ErrorType - Enum in org.apache.avro
- Resolver.Promote - Class in org.apache.avro
-
In this case, the writer's type needs to be promoted to the reader's.
- Resolver.ReaderUnion - Class in org.apache.avro
-
In this case, the reader is a union and the writer is not.
- Resolver.RecordAdjust - Class in org.apache.avro
-
Instructions for resolving two record schemas.
- Resolver.Skip - Class in org.apache.avro
-
This only appears inside
Resolver.RecordAdjust.fieldActions
, i.e., the actions for adjusting the fields of a record. - Resolver.WriterUnion - Class in org.apache.avro
-
In this case, the writer was a union.
- resolveTypeVariables(Class<?>) - Static method in class org.apache.avro.reflect.ReflectionUtil
-
For an interface, get a map of any
TypeVariable
s to their actual types. - 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
- Resolving parser - Search tag in package org.apache.avro.io.parsing
- Section
- ResolvingRecordTest - Class in org.apache.avro.perf.test.record
- ResolvingRecordTest() - Constructor for class org.apache.avro.perf.test.record.ResolvingRecordTest
- ResolvingRecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
- ResolvingRecordTest_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType
- ResolvingRecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B1
- ResolvingRecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- ResolvingRecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B3
- ResolvingRecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType
- ResolvingRecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B1
- ResolvingRecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- ResolvingRecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- ResolvingRecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B3
- ResolvingRecordTest.TestStateDecode - Class in org.apache.avro.perf.test.record
- ResolvingVisitor(Function<String, Schema>) - Constructor for class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- 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
- 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
- Result(String) - Constructor for class org.apache.avro.NameValidator.Result
- resultType() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- resultType() - Method in class org.apache.avro.idl.IdlParser
- ResultTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.ResultTypeContext
- returnType - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- ReusableByteArrayInputStream - Class in org.apache.avro.util
- ReusableByteArrayInputStream() - Constructor for class org.apache.avro.util.ReusableByteArrayInputStream
- ReusableByteBufferInputStream - Class in org.apache.avro.util
- ReusableByteBufferInputStream() - Constructor for class org.apache.avro.util.ReusableByteBufferInputStream
- reusingReader(FastReaderBuilder.ReusingFieldReader) - Static method in class org.apache.avro.io.FastReaderBuilder
- 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.AbstractArray
- rindex - Variable in class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
- rindex - Variable in class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
- rollback() - Method in class org.apache.avro.ParseContext
- ROOT - Enum constant in enum org.apache.avro.io.parsing.Symbol.Kind
-
Start symbol for some grammar
- RParen - Static variable in class org.apache.avro.idl.IdlLexer
- RParen - Static variable in class org.apache.avro.idl.IdlParser
- RParen() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- RParen() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- RParen() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- RParen() - Method in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- 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
- RULE_arrayType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_enumDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_enumDefault - Static variable in class org.apache.avro.idl.IdlParser
- RULE_enumSymbol - Static variable in class org.apache.avro.idl.IdlParser
- RULE_fieldDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_fixedDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_formalParameter - Static variable in class org.apache.avro.idl.IdlParser
- RULE_fullType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_identifier - Static variable in class org.apache.avro.idl.IdlParser
- RULE_idlFile - Static variable in class org.apache.avro.idl.IdlParser
- RULE_importStatement - Static variable in class org.apache.avro.idl.IdlParser
- RULE_jsonArray - Static variable in class org.apache.avro.idl.IdlParser
- RULE_jsonLiteral - Static variable in class org.apache.avro.idl.IdlParser
- RULE_jsonObject - Static variable in class org.apache.avro.idl.IdlParser
- RULE_jsonPair - Static variable in class org.apache.avro.idl.IdlParser
- RULE_jsonValue - Static variable in class org.apache.avro.idl.IdlParser
- RULE_mainSchemaDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_mapType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_messageDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_namedSchemaDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_namespaceDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_nullableType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_plainType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_primitiveType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_protocolDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_protocolDeclarationBody - Static variable in class org.apache.avro.idl.IdlParser
- RULE_recordBody - Static variable in class org.apache.avro.idl.IdlParser
- RULE_recordDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- RULE_resultType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_schemaProperty - Static variable in class org.apache.avro.idl.IdlParser
- RULE_unionType - Static variable in class org.apache.avro.idl.IdlParser
- RULE_variableDeclaration - Static variable in class org.apache.avro.idl.IdlParser
- ruleNames - Static variable in class org.apache.avro.idl.IdlLexer
- ruleNames - Static variable in class org.apache.avro.idl.IdlParser
- 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.DataFileRepairTool
- 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.RecordCountTool
- 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.SchemaFingerprintTool
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.SchemaNormalizationTool
- 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 usesjavax.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 usesjavax.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
. - scale - Variable in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- schema - Variable in class org.apache.avro.reflect.CustomEncoding
- schema - Variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
-
Provided avro schema from the context
- schema() - Method in class org.apache.avro.data.RecordBuilderBase
- schema() - Method in class org.apache.avro.Schema.Field
-
This field's
Schema
. - Schema - Class in org.apache.avro
-
An abstract data type.
- Schema - Static variable in class org.apache.avro.idl.IdlLexer
- Schema - Static variable in class org.apache.avro.idl.IdlParser
- Schema() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Schema() - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- Schema() - Method in class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- SCHEMA - Static variable in class org.apache.avro.data.Json
-
The schema for Json data.
- SCHEMA - Static variable in class org.apache.avro.file.DataFileConstants
- SCHEMA_KEY - Static variable in class org.apache.trevni.avro.AvroColumnWriter
- Schema.Field - Class in org.apache.avro
-
A field within a record.
- 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.SeenPair - Class in org.apache.avro
-
Useful as key of
Map
s when traversing two schemas at the same time and need to watch for recursion. - Schema.Type - Enum in org.apache.avro
-
The type of schema.
- 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 enum org.apache.avro.mapred.tether.TaskType
- 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.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.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> - Class in org.apache.avro -
Abstract base class for field defaults.
- SchemaBuilder.FieldTypeBuilder<R> - Class in org.apache.avro
-
FieldTypeBuilder adds
SchemaBuilder.FieldTypeBuilder.unionOf()
,SchemaBuilder.FieldTypeBuilder.nullable()
, andSchemaBuilder.FieldTypeBuilder.optional()
to BaseFieldTypeBuilder. - 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> - 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.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.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> - Class in org.apache.avro
-
An abstract builder for all Avro types.
- 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 Class in org.apache.avro
-
Thrown for errors building schemas.
- SchemaBuilderException(String) - Constructor for exception class org.apache.avro.SchemaBuilderException
- SchemaBuilderException(Throwable) - Constructor for exception class org.apache.avro.SchemaBuilderException
- SchemaCompatibility - Class in org.apache.avro
-
Evaluate the compatibility between a reader schema and a writer schema.
- SchemaCompatibility.Incompatibility - Class in org.apache.avro
- SchemaCompatibility.SchemaCompatibilityResult - Class in org.apache.avro
-
Immutable class representing details about a particular schema pair compatibility check.
- SchemaCompatibility.SchemaCompatibilityType - Enum in org.apache.avro
-
Identifies the type of a schema compatibility result.
- SchemaCompatibility.SchemaIncompatibilityType - Enum in org.apache.avro
- SchemaCompatibility.SchemaPairCompatibility - Class in org.apache.avro
-
Provides information about the compatibility of a single reader and writer schema pair.
- SchemaFingerprintTool - Class in org.apache.avro.tool
-
Utility to generate fingerprint(s) from a schema.
- SchemaFingerprintTool() - Constructor for class org.apache.avro.tool.SchemaFingerprintTool
- SchemaFormatter - Interface in org.apache.avro
-
Interface and factory to format schemas to text.
- SchemaFormatterFactory - Interface in org.apache.avro
-
Service Provider Interface (SPI) for
SchemaFormatter
. - 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 canonical form of schemas (see
SchemaNormalization.toParsingForm(org.apache.avro.Schema)
) -- and fingerprints of canonical forms (SchemaNormalization.fingerprint(java.lang.String, byte[])
). - SchemaNormalizationTool - Class in org.apache.avro.tool
-
Utility to convert an Avro @{Schema} to its canonical form.
- SchemaNormalizationTool() - Constructor for class org.apache.avro.tool.SchemaNormalizationTool
- SchemaPairCompatibility(SchemaCompatibility.SchemaCompatibilityResult, Schema, Schema, String) - Constructor for class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
-
Constructs a new instance.
- SchemaParseException - Exception Class in org.apache.avro
-
Thrown for errors parsing schemas and protocols.
- SchemaParseException(String) - Constructor for exception class org.apache.avro.SchemaParseException
- SchemaParseException(Throwable) - Constructor for exception class org.apache.avro.SchemaParseException
- SchemaParser - Class in org.apache.avro
-
Avro schema parser for text-based formats like JSON, IDL, etc.
- SchemaParser() - Constructor for class org.apache.avro.SchemaParser
-
Create a schema parser.
- SchemaParser.ParseResult - Interface in org.apache.avro
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.FullTypeContext
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- schemaProperties - Variable in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.FullTypeContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- schemaProperty - Variable in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.FullTypeContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser
- schemaProperty() - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.EnumDeclarationContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.EnumSymbolContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.FullTypeContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.ProtocolDeclarationContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.RecordDeclarationContext
- schemaProperty(int) - Method in class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- SchemaPropertyContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- SchemaResolver - Class in org.apache.avro.util
-
Utility class to resolve schemas that are unavailable at the point they are referenced in a schema file.
- SchemaResolver.IsResolvedSchemaVisitor - Class in org.apache.avro.util
-
This visitor checks if the current schema is fully resolved.
- SchemaResolver.ResolvingVisitor - Class in org.apache.avro.util
-
This visitor creates clone of the visited Schemata, minus the specified schema properties, and resolves all unresolved schemas.
- Schemas - Class in org.apache.avro.compiler.schema
-
Avro Schema utilities, to traverse...
- Schemas - Class in org.apache.avro.util
-
Avro Schema utilities, to traverse...
- SchemaStore - Interface in org.apache.avro.message
-
Interface for classes that can provide avro schemas by fingerprint.
- SchemaStore.Cache - Class in org.apache.avro.message
-
A map-based cache of schemas by AVRO-CRC-64 fingerprint.
- 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
- SchemaUtil - Class in org.apache.avro.util
- SchemaValidationException - Exception Class in org.apache.avro
-
Thrown when
SchemaValidator
fails to validate a schema. - SchemaValidationException(Schema, Schema) - Constructor for exception class org.apache.avro.SchemaValidationException
- SchemaValidationException(Schema, Schema, Throwable) - Constructor for exception class org.apache.avro.SchemaValidationException
- SchemaValidationStrategy - Interface in org.apache.avro
-
An interface for validating the compatibility of a single schema against another.
- SchemaValidator - Interface in org.apache.avro
-
A SchemaValidator has one method, which validates that a
Schema
is compatible with the other schemas provided. - SchemaValidatorBuilder - Class in org.apache.avro
-
A Builder for creating SchemaValidators.
- SchemaValidatorBuilder() - Constructor for class org.apache.avro.SchemaValidatorBuilder
- SchemaVisitor<T> - Interface in org.apache.avro.compiler.schema
- SchemaVisitor<T> - Interface in org.apache.avro.util
- SchemaVisitor.SchemaVisitorAction - Enum in org.apache.avro.util
- SchemaVisitorAction - Enum in org.apache.avro.compiler.schema
- 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 implementsSeekableInput
. - 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.
- SeenPair(Object, Object) - Constructor for class org.apache.avro.Schema.SeenPair
- Segment(int, int) - Constructor for class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Segment
- Selecting and Building an Avro Type - Search tag in class org.apache.avro.SchemaBuilder
- Section
- 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 class org.apache.avro.idl.IdlLexer
- Semicolon - Static variable in class org.apache.avro.idl.IdlParser
- Semicolon() - Method in class org.apache.avro.idl.IdlParser.EnumDefaultContext
- Semicolon() - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- Semicolon() - Method in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- Semicolon() - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- Semicolon() - Method in class org.apache.avro.idl.IdlParser.MainSchemaDeclarationContext
- Semicolon() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- Semicolon() - Method in class org.apache.avro.idl.IdlParser.NamespaceDeclarationContext
- SEQUENCE - Enum constant in enum org.apache.avro.io.parsing.Symbol.Kind
-
non-terminal symbol which is a sequence of one or more other symbols
- 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
- SERIALIZABLE_PACKAGES - Static variable in class org.apache.avro.specific.SpecificDatumReader
- 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
- 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
- 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
- set(int, boolean) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- set(int, double) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- set(int, float) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- set(int, int) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- set(int, long) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- set(int, Boolean) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- set(int, Double) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- set(int, Float) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- set(int, Integer) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- set(int, Long) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- set(int, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Sets the value of a field.
- set(int, T) - Method in class org.apache.avro.generic.GenericData.Array
- 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, long) - Method in class org.apache.trevni.MetaData
-
Set a metadata property to a long value.
- set(String, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Sets the value of a field.
- set(String, String) - Method in class org.apache.trevni.MetaData
-
Set a metadata property to a String value.
- set(K, V) - Method in class org.apache.avro.mapred.Pair
-
Set both the key and value.
- set(Schema.Field, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Sets the value of a field.
- set(Utf8) - Method in class org.apache.avro.util.Utf8
- setAdditionalVelocityTools(List<Object>) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Set additional Velocity tools (simple POJOs) to be injected into the Velocity template context.
- setByteArray(byte[], int, int) - Method in class org.apache.avro.util.ReusableByteArrayInputStream
- setByteBuffer(ByteBuffer) - Method in class org.apache.avro.util.ReusableByteBufferInputStream
- 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(String) - Method in class org.apache.trevni.MetaData
-
Set the compression codec name.
- setCodec(CodecFactory) - Method in class org.apache.avro.file.DataFileWriter
-
Configures this writer to use the given codec.
- setCombinerClass(JobConf, Class<? extends AvroReducer>) - Static method in class org.apache.avro.mapred.AvroJob
-
Configure a job's combiner implementation.
- setConf(Configuration) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
- setConf(Configuration) - Method in class org.apache.avro.mapred.AvroKeyComparator
- setCountersEnabled(JobConf, boolean) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
-
Enables or disables counters for the named outputs.
- setCountersEnabled(Job, boolean) - Static method in class org.apache.avro.mapreduce.AvroMultipleOutputs
-
Enables or disables counters for the named outputs.
- setCreateNullSafeAnnotations(boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Set to true to add jetbrains @Nullable and @NotNull annotations
- setCreateOptionalGetters(boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Set to false to not create the getters that return an Optional.
- 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.
- setCustomCoders(boolean) - Method in class org.apache.avro.specific.SpecificData
-
Dynamically set the value of the custom-coder feature flag.
- setDataModelClass(Configuration, Class<? extends GenericData>) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
-
Sets the data model class for de/serialization.
- setDataModelClass(JobConf, Class<? extends GenericData>) - Static method in class org.apache.avro.mapred.AvroJob
-
Configure a job's data model implementation class.
- setDataModelClass(Job, Class<? extends GenericData>) - Static method in class org.apache.avro.mapreduce.AvroJob
-
Sets the job data model class.
- setDatas(List<ByteBuffer>) - Method in class org.apache.avro.ipc.netty.NettyTransportCodec.NettyDataPack
- setDefaultGeneratedValue(Type, Object) - Method in class org.apache.avro.reflect.ReflectData
-
Set the default value for a type.
- setDefaultsGenerated(boolean) - Method in class org.apache.avro.reflect.ReflectData
-
Enable or disable `default reflection`
- 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
- setEnableDecimalLogicalType(boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Set to true to use
BigDecimal
instead ofByteBuffer
for logical type "decimal" - setEncoder(Function<OutputStream, BinaryEncoder>) - Method in class org.apache.avro.file.DataFileWriter
-
Allows setting a different encoder than the default DirectBinaryEncoder.
- setErrorSpecificClass(String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- 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.
- setFastReaderEnabled(boolean) - Method in class org.apache.avro.generic.GenericData
- setField(Object, String, int, Object) - Method in class org.apache.avro.generic.GenericData
-
Called by
GenericDatumReader.readRecord(java.lang.Object, org.apache.avro.Schema, org.apache.avro.io.ResolvingDecoder)
to set a record fields value to a record instance. - setField(Object, String, int, 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) - Method in class org.apache.avro.thrift.ThriftData
- setField(Object, String, int, Object, Object) - Method in class org.apache.avro.generic.GenericData
-
Version of
GenericData.setField(java.lang.Object, java.lang.String, int, java.lang.Object)
that has state. - setField(Object, String, int, Object, Object) - Method in class org.apache.avro.protobuf.ProtobufData
- setField(Object, String, int, Object, Object) - Method in class org.apache.avro.reflect.ReflectData
- 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.
- setGettersReturnOptional(boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Set to false to not create the getters that return an Optional.
- 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.
- setIncludeNamespace(boolean) - Method in class org.apache.avro.io.JsonEncoder
- 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.BlockingDirectBinaryEncoder
- 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.call
Utf8.setByteLength(int)
instead. - 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.
- setMessage(Protocol.Message) - Method in class org.apache.avro.ipc.RPCContext
-
Sets the
Protocol.Message
corresponding to this RPC - setMeta(String, byte[]) - 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(String, String) - 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.
- setNameValidator(NameValidator) - Static method in class org.apache.avro.Schema
-
Deprecated.
- setOptionalGettersForNullableFieldsOnly(boolean) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Set to true to create the Optional getters only for nullable fields.
- setOutputCharacterEncoding(String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Sets character encoding for generated java file
- 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, byte[]) - 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, String) - 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.
- setProtocol(JobConf, String) - Static method in class org.apache.avro.mapred.tether.TetherJob
-
Determines which transport protocol (e.g http or sasl) used to communicate between the parent and subprocess
- setRecordSpecificClass(String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- 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.netty.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.
- setRequestPayload(List<ByteBuffer>) - Method in class org.apache.avro.ipc.RPCContext
-
Sets the serialized payload of the request in this RPC.
- setResponsePayload(List<ByteBuffer>) - Method in class org.apache.avro.ipc.RPCContext
-
Sets the serialized payload of the response in this RPC.
- setSchema(Schema) - Method in class org.apache.avro.data.Json.ObjectReader
- setSchema(Schema) - Method in class org.apache.avro.data.Json.ObjectWriter
- 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 interface org.apache.avro.io.FastReaderBuilder.FieldReader
- 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.netty.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.
- 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.
- setSuffix(String) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Set the resource file suffix, .java or .xxx
- 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
. - 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.
- setTypes(Collection<Schema>) - Method in class org.apache.avro.Protocol
-
Set the types of this protocol.
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- setValidateDefaults(boolean) - Method in class org.apache.avro.Schema.Parser
-
Enable or disable default value validation.
- setValidateDefaults(boolean) - Static method in class org.apache.avro.Schema
-
Deprecated.
- setValue(Object) - Method in interface org.apache.avro.data.ErrorBuilder
-
Sets the value
- setValue(Object) - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
- setValue(V) - Method in class org.apache.avro.hadoop.io.AvroKeyValue
-
Sets the value.
- setValue(V) - Method in class org.apache.avro.reflect.MapEntry
-
Deprecated.
- setValue(V) - Method in class org.apache.avro.util.MapEntry
- setValue(V) - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Entry
- 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.
- SingleLineComment - Static variable in class org.apache.avro.idl.IdlLexer
- SingleLineComment - Static variable in class org.apache.avro.idl.IdlParser
- size - Variable in class org.apache.avro.generic.GenericData.AbstractArray
- size - Variable in class org.apache.avro.idl.IdlParser.FixedDeclarationContext
- size - Variable in class org.apache.avro.io.parsing.Symbol.IntCheckAction
- size() - Method in class org.apache.avro.generic.GenericData.AbstractArray
- size() - Method in class org.apache.avro.io.parsing.Symbol.Alternative
- size() - Method in class org.apache.avro.io.parsing.Symbol.Sequence
- size() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap
- size() - Method in class org.apache.avro.util.WeakIdentityHashMap
- size(int) - Method in class org.apache.avro.SchemaBuilder.FixedBuilder
-
Configure this fixed type's size, and end its configuration.
- 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.
- SIZES_DONT_MATCH - Enum constant in enum org.apache.avro.Resolver.ErrorAction.ErrorType
-
Use when two fixed types match and their names match by their sizes don't.
- skip(long) - Method in class org.apache.avro.util.ReusableByteBufferInputStream
- skip(Schema, Decoder) - Static method in class org.apache.avro.generic.GenericDatumReader
-
Skip an instance of a schema.
- Skip(Schema, GenericData) - Constructor for class org.apache.avro.Resolver.Skip
- SKIP - Enum constant in enum org.apache.avro.Resolver.Action.Type
- SKIP_SIBLINGS - Enum constant in enum org.apache.avro.compiler.schema.SchemaVisitorAction
-
Skip visiting the siblings of this schema.
- SKIP_SIBLINGS - Enum constant in enum org.apache.avro.util.SchemaVisitor.SchemaVisitorAction
-
Skip visiting the siblings of this schema.
- SKIP_SUBTREE - Enum constant in enum org.apache.avro.compiler.schema.SchemaVisitorAction
-
when returned from pre non terminal visit method the children of the non terminal are skipped. afterVisitNonTerminal for the current schema will not be invoked.
- SKIP_SUBTREE - Enum constant in enum org.apache.avro.util.SchemaVisitor.SchemaVisitorAction
-
when returned from pre non terminal visit method the children of the non terminal are skipped. afterVisitNonTerminal for the current schema will not be invoked.
- skipAction() - Method in interface org.apache.avro.io.parsing.SkipParser.SkipHandler
-
Skips the action at the top of the stack.
- skipAction() - Method in class org.apache.avro.io.ParsingDecoder
- skipAction() - Method in class org.apache.avro.io.ResolvingDecoder
- skipAction(Symbol) - Static method in class org.apache.avro.io.parsing.Symbol
- SkipAction(Symbol) - Constructor for class org.apache.avro.io.parsing.Symbol.SkipAction
-
Deprecated.
- 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.ResolvingDecoder
- skipBytes() - Method in class org.apache.avro.io.ValidatingDecoder
- skipFixed() - Method in class org.apache.avro.io.JsonDecoder
- skipFixed() - Method in class org.apache.avro.io.ParsingDecoder
- skipFixed() - 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(int) - 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.ResolvingDecoder
- 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
orreadXyz
methods onthis
, 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
- SmallLongTest - Class in org.apache.avro.perf.test.basic
- SmallLongTest() - Constructor for class org.apache.avro.perf.test.basic.SmallLongTest
- SmallLongTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
- SmallLongTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_encode_jmhTest
- SmallLongTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType
- SmallLongTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B1
- SmallLongTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- SmallLongTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B3
- SmallLongTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType
- SmallLongTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B1
- SmallLongTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- SmallLongTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B3
- SmallLongTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType
- SmallLongTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B1
- SmallLongTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- SmallLongTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- SmallLongTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B3
- SmallLongTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- SmallLongTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- SNAPPY_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
- snappyCodec() - Static method in class org.apache.avro.file.CodecFactory
-
Snappy codec.
- SnappyCodec - Class in org.apache.avro.file
-
Implements Snappy compression and decompression.
- 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.use
SaslSocketTransceiver
instead. - SocketTransceiver(SocketAddress) - Constructor for class org.apache.avro.ipc.SocketTransceiver
-
Deprecated.
- SocketTransceiver(SocketChannel) - Constructor for class org.apache.avro.ipc.SocketTransceiver
-
Deprecated.
- SOFT - Enum constant in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.ReferenceType
-
Use
SoftReferences
. - SortedKeyValueFile - Class in org.apache.avro.hadoop.file
-
A SortedKeyValueFile is an indexed Avro container file of KeyValue records sorted by key.
- SortedKeyValueFile() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile
- SortedKeyValueFile.Reader<K,
V> - Class in org.apache.avro.hadoop.file -
Reads a SortedKeyValueFile by loading the key index into memory.
- SortedKeyValueFile.Reader.Options - Class in org.apache.avro.hadoop.file
-
A class to encapsulate the options of a Reader.
- SortedKeyValueFile.Writer<K,
V> - Class in org.apache.avro.hadoop.file -
Writes a SortedKeyValueFile.
- SortedKeyValueFile.Writer.Options - Class in org.apache.avro.hadoop.file
-
A class to encapsulate the various options of a SortedKeyValueFile.Writer.
- space() - Element in annotation type org.apache.avro.reflect.AvroAlias
- SpecificCompiler - Class in org.apache.avro.compiler.specific
-
Generate specific Java interfaces and classes for protocols and schemas.
- SpecificCompiler(Iterable<Schema>) - Constructor for class org.apache.avro.compiler.specific.SpecificCompiler
- SpecificCompiler(Collection<Schema>) - Constructor for class org.apache.avro.compiler.specific.SpecificCompiler
- 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
- 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> - 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(Schema, SpecificData) - 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 Class in org.apache.avro.specific
-
Base class for specific exceptions.
- SpecificExceptionBase() - Constructor for exception class org.apache.avro.specific.SpecificExceptionBase
- SpecificExceptionBase(Object) - Constructor for exception class org.apache.avro.specific.SpecificExceptionBase
- SpecificExceptionBase(Object, Throwable) - Constructor for exception class org.apache.avro.specific.SpecificExceptionBase
- SpecificExceptionBase(Throwable) - Constructor for exception class 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> - 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(Schema, SpecificData) - 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(Class<?>, Transceiver, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
- SpecificRequestor(Protocol, Transceiver) - 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(Class, Object, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
- SpecificResponder(Protocol, Object) - 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.jetty.HttpServer
-
Start the server.
- start() - Method in class org.apache.avro.ipc.netty.NettyServer
- start() - Method in interface org.apache.avro.ipc.Server
-
Start this server.
- startInitialization() - Method in class org.apache.avro.io.FastReaderBuilder.RecordReader
- 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()
orColumnValues.nextValue()
. - startupTime - Variable in class org.apache.avro.ipc.stats.StatsPlugin
-
How long I've been alive
- StaticServlet - Class in org.apache.avro.ipc.jetty
-
Very simple servlet class capable of serving static files.
- StaticServlet() - Constructor for class org.apache.avro.ipc.jetty.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.
- StatsPlugin(Stopwatch.Ticks, Histogram.Segmenter<?, Float>, Histogram.Segmenter<?, Integer>) - Constructor for class org.apache.avro.ipc.stats.StatsPlugin
-
Construct a plugin with custom Ticks and Segmenter implementations.
- StatsServer - Class in org.apache.avro.ipc.jetty
- StatsServer(StatsPlugin, int) - Constructor for class org.apache.avro.ipc.jetty.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
- 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.jetty.StatsServer
- strategy(SchemaValidationStrategy) - Method in class org.apache.avro.SchemaValidatorBuilder
- stream(Object) - Method in class org.apache.avro.grpc.AvroResponseMarshaller
- stream(Object[]) - Method in class org.apache.avro.grpc.AvroRequestMarshaller
- STRICT_VALIDATOR - Static variable in interface org.apache.avro.NameValidator
- String - Enum constant in enum org.apache.avro.generic.GenericData.StringType
- String - Static variable in class org.apache.avro.idl.IdlLexer
- String - Static variable in class org.apache.avro.idl.IdlParser
- String() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- String() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- STRING - Enum constant in enum org.apache.avro.Schema.Type
- STRING - Enum constant in enum org.apache.trevni.ValueType
- STRING - Static variable in class org.apache.avro.io.parsing.Symbol
- 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.
- StringLiteral - Static variable in class org.apache.avro.idl.IdlLexer
- StringLiteral - Static variable in class org.apache.avro.idl.IdlParser
- StringLiteral() - Method in class org.apache.avro.idl.IdlParser.ImportStatementContext
- StringLiteral() - Method in class org.apache.avro.idl.IdlParser.JsonLiteralContext
- StringLiteral() - Method in class org.apache.avro.idl.IdlParser.JsonPairContext
- StringTest - Class in org.apache.avro.perf.test.basic
- StringTest() - Constructor for class org.apache.avro.perf.test.basic.StringTest
- StringTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
- StringTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_encode_jmhTest
- StringTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType
- StringTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B1
- StringTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- StringTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B3
- StringTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType
- StringTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B1
- StringTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- StringTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B3
- StringTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType
- StringTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B1
- StringTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- StringTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- StringTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B3
- StringTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- StringTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- 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.
- 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
- subtractFrom(Temporal) - Method in class org.apache.avro.util.TimePeriod
- summarize(Schema) - Method in interface org.apache.avro.path.PathTracingException
-
produces a user-facing exception to be thrown back out to user code
- summarize(Schema) - Method in exception class org.apache.avro.path.TracingAvroTypeException
- summarize(Schema) - Method in exception class org.apache.avro.path.TracingClassCastException
- summarize(Schema) - Method in exception class org.apache.avro.path.TracingNullPointException
- swap(int, int) - Method in class org.apache.avro.generic.GenericData.AbstractArray
- swap(int, int) - Method in class org.apache.avro.generic.GenericData.Array
- swap(int, int) - Method in class org.apache.avro.generic.PrimitivesArrays.BooleanArray
- swap(int, int) - Method in class org.apache.avro.generic.PrimitivesArrays.DoubleArray
- swap(int, int) - Method in class org.apache.avro.generic.PrimitivesArrays.FloatArray
- swap(int, int) - Method in class org.apache.avro.generic.PrimitivesArrays.IntArray
- swap(int, int) - Method in class org.apache.avro.generic.PrimitivesArrays.LongArray
- 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.EnumAdjustAction - Class in org.apache.avro.io.parsing
- Symbol.EnumLabelsAction - Class in org.apache.avro.io.parsing
- Symbol.ErrorAction - Class in org.apache.avro.io.parsing
- Symbol.FieldAdjustAction - Class in org.apache.avro.io.parsing
- Symbol.FieldOrderAction - Class in org.apache.avro.io.parsing
- Symbol.ImplicitAction - Class in org.apache.avro.io.parsing
- Symbol.IntCheckAction - Class in org.apache.avro.io.parsing
- 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.UnionAdjustAction - Class in org.apache.avro.io.parsing
- 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() - Method in class org.apache.avro.file.DataFileWriter
-
Return the current position as a value that may be passed to
DataFileReader.seek(long)
. - 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() - 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() - Method in interface org.apache.avro.mapreduce.Syncable
-
Return the current position as a value that may be passed to DataFileReader.seek(long).
- 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(long) - Method in interface org.apache.avro.file.FileReader
-
Move to the next synchronization point after a position.
- sync(long) - Method in class org.apache.avro.mapred.SequenceFileReader
- sync(String, String) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
-
Gets the record writer from job's output format.
- 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(File) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
Creates an instance of SyncableFileOutputStream using the given File instance.
- SyncableFileOutputStream(FileDescriptor) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
Creates an instance of SyncableFileOutputStream using the given FileDescriptor instance.
- 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(String) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
Creates an instance of SyncableFileOutputStream with the given name.
- 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.
- 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.
- SystemLimitException - Exception Class in org.apache.avro
-
Thrown to prevent making large allocations when reading potentially pathological input data from an untrusted source.
- SystemLimitException(String) - Constructor for exception class org.apache.avro.SystemLimitException
T
- T__0 - Static variable in class org.apache.avro.idl.IdlLexer
- T__0 - Static variable in class org.apache.avro.idl.IdlParser
- TaskType - Enum in org.apache.avro.mapred.tether
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- tearInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- tearIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutex - Variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateDecode_jmhType_B2
- tearTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_TestStateEncode_jmhType_B2
- 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.
- TERMINAL - Enum constant in enum org.apache.avro.io.parsing.Symbol.Kind
-
terminal symbols which have no productions
- TERMINATE - Enum constant in enum org.apache.avro.compiler.schema.SchemaVisitorAction
-
terminate visit.
- TERMINATE - Enum constant in enum org.apache.avro.util.SchemaVisitor.SchemaVisitorAction
-
terminate visit.
- testExcludes - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
A set of Ant-like exclusion patterns used to prevent certain files from being processed.
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.ArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.BooleanTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.BytesTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.DoubleTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.FloatTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.IntTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.LongTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.MapTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.SmallLongTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.StringTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.generic.GenericStringTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.generic.GenericTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.generic.GenericWithPromotionTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.record.RecordTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.record.RecordWithDefaultTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.record.RecordWithPromotionTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.record.ResolvingRecordTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateDecode
- TestStateDecode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateDecode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.ArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.BooleanTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.BytesTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.DoubleTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.FloatTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.IntTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.LongTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.MapTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.SmallLongTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.StringTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.generic.GenericStringTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.generic.GenericTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateEncode
- TestStateEncode() - Constructor for class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateEncode
- TETHER_EXEC - Static variable in class org.apache.avro.mapred.tether.TetherJob
- TETHER_EXEC_ARGS - Static variable in class org.apache.avro.mapred.tether.TetherJob
- TETHER_EXEC_CACHED - Static variable in class org.apache.avro.mapred.tether.TetherJob
- TETHER_PROTOCOL - Static variable in class org.apache.avro.mapred.tether.TetherJob
- TetherJob - Class in org.apache.avro.mapred.tether
-
Constructs and submits tether jobs.
- TetherJob() - Constructor for class org.apache.avro.mapred.tether.TetherJob
- 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.
- TextConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.TextConverter
-
Constructor.
- The interpretation - Search tag in package org.apache.avro.io.parsing
- Section
- 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 class org.apache.avro.idl.IdlLexer
- Throws - Static variable in class org.apache.avro.idl.IdlParser
- Throws() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Throws() - Method in class org.apache.avro.idl.IdlParser.MessageDeclarationContext
- Time - Static variable in class org.apache.avro.idl.IdlLexer
- Time - Static variable in class org.apache.avro.idl.IdlParser
- Time() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Time() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- TimeConversions - Class in org.apache.avro.data
- TimeConversions() - Constructor for class org.apache.avro.data.TimeConversions
- TimeConversions.DateConversion - Class in org.apache.avro.data
- TimeConversions.LocalTimestampMicrosConversion - Class in org.apache.avro.data
- TimeConversions.LocalTimestampMillisConversion - Class in org.apache.avro.data
- TimeConversions.LocalTimestampNanosConversion - Class in org.apache.avro.data
- TimeConversions.TimeMicrosConversion - Class in org.apache.avro.data
- TimeConversions.TimeMillisConversion - Class in org.apache.avro.data
- TimeConversions.TimestampMicrosConversion - Class in org.apache.avro.data
- TimeConversions.TimestampMillisConversion - Class in org.apache.avro.data
- TimeConversions.TimestampNanosConversion - Class in org.apache.avro.data
- timeMicros() - Static method in class org.apache.avro.LogicalTypes
- TimeMicrosConversion() - Constructor for class org.apache.avro.data.TimeConversions.TimeMicrosConversion
- timeMillis() - Static method in class org.apache.avro.LogicalTypes
- TimeMillisConversion() - Constructor for class org.apache.avro.data.TimeConversions.TimeMillisConversion
- TimePeriod - Class in org.apache.avro.util
-
A temporal amount to model an
Avro duration
(the logical type). - Timestamp - Static variable in class org.apache.avro.idl.IdlLexer
- Timestamp - Static variable in class org.apache.avro.idl.IdlParser
- Timestamp() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Timestamp() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- timestampMicros() - Static method in class org.apache.avro.LogicalTypes
- TimestampMicrosConversion() - Constructor for class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
- TimestampMicrosConversion() - Constructor for class org.apache.avro.protobuf.ProtoConversions.TimestampMicrosConversion
- timestampMillis() - Static method in class org.apache.avro.LogicalTypes
- TimestampMillisConversion() - Constructor for class org.apache.avro.data.TimeConversions.TimestampMillisConversion
- TimestampMillisConversion() - Constructor for class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
- timestampNanos() - Static method in class org.apache.avro.LogicalTypes
- TimestampNanosConversion() - Constructor for class org.apache.avro.data.TimeConversions.TimestampNanosConversion
- TimestampNanosConversion() - Constructor for class org.apache.avro.protobuf.ProtoConversions.TimestampNanosConversion
- toArray(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toBoolean(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toByteBuffer() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Serializes this HandshakeRequest to a ByteBuffer.
- toByteBuffer() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Serializes this HandshakeResponse to a ByteBuffer.
- toBytes(BigDecimal, Schema, LogicalType) - Method in class org.apache.avro.Conversions.BigDecimalConversion
- toBytes(BigDecimal, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DecimalConversion
- toBytes(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toCharSequence(UUID, Schema, LogicalType) - Method in class org.apache.avro.Conversions.UUIDConversion
- toCharSequence(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toDouble(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toDuration() - Method in class org.apache.avro.util.TimePeriod
- toEnumSymbol(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toFixed(BigDecimal, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DecimalConversion
- toFixed(UUID, Schema, LogicalType) - Method in class org.apache.avro.Conversions.UUIDConversion
- toFixed(TimePeriod, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DurationConversion
- toFixed(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toFloat(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toInt(LocalDate, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.DateConversion
- toInt(LocalTime, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimeMillisConversion
- toInt(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toJson(Input, PrintStream, boolean) - Method in class org.apache.avro.tool.TrevniToJsonTool
-
Read a Trevni file and print each row as a JSON object.
- tokenNames - Static variable in class org.apache.avro.idl.IdlLexer
-
Deprecated.Use
IdlLexer.VOCABULARY
instead. - tokenNames - Static variable in class org.apache.avro.idl.IdlParser
-
Deprecated.Use
IdlParser.VOCABULARY
instead. - toLong(Timestamp, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMicrosConversion
- toLong(Timestamp, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
- toLong(Timestamp, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampNanosConversion
- toLong(Instant, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
- toLong(Instant, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampMillisConversion
- toLong(Instant, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampNanosConversion
- toLong(LocalDateTime, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMicrosConversion
- toLong(LocalDateTime, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMillisConversion
- toLong(LocalDateTime, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampNanosConversion
- toLong(LocalTime, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimeMicrosConversion
- toLong(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toMap(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- 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.
- toPeriod() - Method in class org.apache.avro.util.TimePeriod
- topSymbol() - Method in class org.apache.avro.io.parsing.Parser
-
Returns the top symbol from the stack.
- toRecord(T, Schema, LogicalType) - Method in class org.apache.avro.Conversion
- toString() - Method in exception class org.apache.avro.AvroMissingFieldException
- toString() - Method in class org.apache.avro.compiler.schema.CloningVisitor
- 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.DeflateCodec
- toString() - Method in class org.apache.avro.file.XZCodec
- toString() - Method in class org.apache.avro.file.ZstandardCodec
- 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() - 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.path.ArrayPositionPredicate
- toString() - Method in class org.apache.avro.path.LocationStep
- toString() - Method in class org.apache.avro.path.MapKeyPredicate
- toString() - Method in class org.apache.avro.path.UnionTypePredicate
- toString() - Method in class org.apache.avro.Protocol.Message
- toString() - Method in class org.apache.avro.Protocol
-
Render this as JSON.
- toString() - Method in class org.apache.avro.Resolver.ErrorAction
- toString() - Method in class org.apache.avro.Schema.Field
- toString() - Method in class org.apache.avro.Schema
-
Render this as JSON.
- toString() - Method in class org.apache.avro.SchemaCompatibility.Incompatibility
- toString() - Method in class org.apache.avro.SchemaCompatibility.SchemaCompatibilityResult
- toString() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
- toString() - Method in class org.apache.avro.specific.SpecificFixed
- toString() - Method in class org.apache.avro.specific.SpecificRecordBase
- toString() - Method in class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- toString() - Method in class org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Entry
- toString() - Method in class org.apache.avro.util.TimePeriod
- toString() - Method in class org.apache.avro.util.Utf8
- toString() - Method in class org.apache.trevni.MetaData
- toString(boolean) - Method in class org.apache.avro.Protocol
-
Render this as JSON.
- toString(boolean) - Method in class org.apache.avro.Schema
-
Deprecated.
- toString(Object) - Static method in class org.apache.avro.data.Json
-
Converts an instance of the object model described in
JsonProperties
to a JSON string. - toString(Object) - Method in class org.apache.avro.generic.GenericData
-
Renders a Java datum as JSON.
- toString(Object, StringBuilder, IdentityHashMap<Object, Object>) - Method in class org.apache.avro.generic.GenericData
-
Renders a Java datum as JSON.
- toString(Collection<Schema>, boolean) - Method in class org.apache.avro.Schema
-
Deprecated.
- 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
- tracePath(PathElement) - Method in interface org.apache.avro.path.PathTracingException
-
appends a path element to the trace. expected to be called in reverse-order as the exception bubbles up the stack
- tracePath(PathElement) - Method in exception class org.apache.avro.path.TracingAvroTypeException
- tracePath(PathElement) - Method in exception class org.apache.avro.path.TracingClassCastException
- tracePath(PathElement) - Method in exception class org.apache.avro.path.TracingNullPointException
- TracingAvroTypeException - Exception Class in org.apache.avro.path
-
an
AvroTypeException
with extra fields used to trace back the path to a bad value through an object graph - TracingAvroTypeException(AvroTypeException) - Constructor for exception class org.apache.avro.path.TracingAvroTypeException
- TracingClassCastException - Exception Class in org.apache.avro.path
-
a
ClassCastException
with extra fields used to trace back the path to a bad value through an object graph - TracingClassCastException(ClassCastException, Object, Schema, boolean) - Constructor for exception class org.apache.avro.path.TracingClassCastException
- TracingNullPointException - Exception Class in org.apache.avro.path
-
a
NullPointerException
with extra fields used to trace back the path to a null value through an object graph - TracingNullPointException(NullPointerException, Schema, boolean) - Constructor for exception class org.apache.avro.path.TracingNullPointException
- transceive(List<ByteBuffer>) - Method in class org.apache.avro.ipc.LocalTransceiver
- transceive(List<ByteBuffer>) - Method in class org.apache.avro.ipc.netty.NettyTransceiver
-
Override as non-synchronized method because the method is thread safe.
- 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.netty.NettyTransceiver
- 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
- TransceiverCallback(Requestor.Request, Callback<T>) - Constructor for class org.apache.avro.ipc.Requestor.TransceiverCallback
-
Creates a TransceiverCallback.
- 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 Class in org.apache.trevni
-
Base runtime exception thrown by Trevni.
- TrevniRuntimeException(String) - Constructor for exception class org.apache.trevni.TrevniRuntimeException
- TrevniRuntimeException(String, Throwable) - Constructor for exception class org.apache.trevni.TrevniRuntimeException
- TrevniRuntimeException(Throwable) - Constructor for exception class 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
- type - Variable in class org.apache.avro.Resolver.Action
- type() - 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.BaseTypeBuilder
-
Look up the type by name.
- 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.BaseTypeBuilder
-
Look up the type by name and namespace.
- type(String, String) - 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.BaseTypeBuilder
-
Use the schema provided as the type.
- type(Schema) - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
-
Final step in configuring this field, finalizing name, namespace, alias, and order.
- TYPE_IDENTIFIER_RESERVED_WORDS - Static variable in class org.apache.avro.specific.SpecificData
- TYPE_MISMATCH - Enum constant in enum org.apache.avro.SchemaCompatibility.SchemaIncompatibilityType
- typeName - Variable in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- types - Variable in class org.apache.avro.idl.IdlParser.UnionTypeContext
- typesByName() - Method in class org.apache.avro.ParseContext
-
Return all known types by their fullname.
U
- UnchangedUnionTest - Class in org.apache.avro.perf.test.basic
- UnchangedUnionTest() - Constructor for class org.apache.avro.perf.test.basic.UnchangedUnionTest
- UnchangedUnionTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
- UnchangedUnionTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_encode_jmhTest
- UnchangedUnionTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType
- UnchangedUnionTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B1
- UnchangedUnionTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B2
- UnchangedUnionTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_jmhType_B3
- UnchangedUnionTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType
- UnchangedUnionTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B1
- UnchangedUnionTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
- UnchangedUnionTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateDecode_jmhType_B3
- UnchangedUnionTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType
- UnchangedUnionTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B1
- UnchangedUnionTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
- UnchangedUnionTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
- UnchangedUnionTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_TestStateEncode_jmhType_B3
- UnchangedUnionTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
- UnchangedUnionTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
- uncheckExceptions(Callable<T>) - Static method in class org.apache.avro.idl.IdlUtils
-
Calls the given callable, wrapping any checked exception in an
AvroRuntimeException
. - Union - Annotation Type in org.apache.avro.reflect
-
Declares that a Java type should be represented by an Avro union schema.
- Union - Static variable in class org.apache.avro.idl.IdlLexer
- Union - Static variable in class org.apache.avro.idl.IdlParser
- Union() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Union() - Method in class org.apache.avro.idl.IdlParser.UnionTypeContext
- UNION - Enum constant in enum org.apache.avro.Schema.Type
- UNION - Static variable in class org.apache.avro.io.parsing.Symbol
- 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
- UnionAdjustAction(int, Symbol) - Constructor for class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
-
Deprecated.
- unionEquiv - Variable in class org.apache.avro.Resolver.WriterUnion
- 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:
- Unions - Search tag in class org.apache.avro.SchemaBuilder
- Section
- unionType() - Method in class org.apache.avro.idl.IdlParser.PlainTypeContext
- unionType() - Method in class org.apache.avro.idl.IdlParser
- UnionTypeContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.UnionTypeContext
- UnionTypePredicate - Class in org.apache.avro.path
-
Returns items by their position (numeric index of type) in a union schema
- UnionTypePredicate(String) - Constructor for class org.apache.avro.path.UnionTypePredicate
- UnknownAvroCodecException - Exception Class in org.apache.avro
- UnknownAvroCodecException(String) - Constructor for exception class org.apache.avro.UnknownAvroCodecException
- unlockChannel() - Method in class org.apache.avro.ipc.netty.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.
- unmangle(String) - Static method in class org.apache.avro.specific.SpecificData
-
Undoes mangling for reserved words.
- unresolvedSchema(String) - Static method in class org.apache.avro.util.SchemaResolver
-
Create a schema to represent an "unresolved" schema.
- UnresolvedUnionException - Exception Class in org.apache.avro
-
Thrown when the expected contents of a union cannot be resolved.
- UnresolvedUnionException(Schema, Object) - Constructor for exception class org.apache.avro.UnresolvedUnionException
- UnresolvedUnionException(Schema, Schema.Field, Object) - Constructor for exception class org.apache.avro.UnresolvedUnionException
- Usage Guide - Search tag in class org.apache.avro.SchemaBuilder
- Section
- USE_DEFAULT - Static variable in class org.apache.avro.util.RandomData
- useCustomCoders() - Method in class org.apache.avro.reflect.ReflectData
-
Always false since custom coders are not available for
ReflectData
. - useCustomCoders() - Method in class org.apache.avro.specific.SpecificData
-
Retrieve the current value of the custom-coders feature flag.
- using() - Element in annotation type org.apache.avro.reflect.AvroEncode
- UTF_VALIDATOR - Static variable in interface org.apache.avro.NameValidator
- Utf8 - Class in org.apache.avro.util
-
A Utf8 string.
- Utf8 - Enum constant in enum org.apache.avro.generic.GenericData.StringType
- Utf8() - Constructor for class org.apache.avro.util.Utf8
- Utf8(byte[]) - 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
- UtfTextUtils - Class in org.apache.avro.util
-
Text utilities especially suited for UTF encoded bytes.
- UtfTextUtils() - Constructor for class org.apache.avro.util.UtfTextUtils
- uuid() - Static method in class org.apache.avro.LogicalTypes
- UUID - Static variable in class org.apache.avro.idl.IdlLexer
- UUID - Static variable in class org.apache.avro.idl.IdlParser
- UUID() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- UUID() - Method in class org.apache.avro.idl.IdlParser.PrimitiveTypeContext
- UUIDConversion() - Constructor for class org.apache.avro.Conversions.UUIDConversion
V
- validate(String) - Method in interface org.apache.avro.NameValidator
- validate(Schema) - Method in class org.apache.avro.LogicalType
-
Validate this logical type for the given Schema.
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.BigDecimal
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.Date
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.Decimal
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.Duration
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.LocalTimestampMicros
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.LocalTimestampMillis
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.LocalTimestampNanos
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.TimeMicros
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.TimeMillis
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.TimestampMicros
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.TimestampMillis
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.TimestampNanos
- validate(Schema) - Method in class org.apache.avro.LogicalTypes.Uuid
- 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, Iterable<Schema>) - Method in interface org.apache.avro.SchemaValidator
-
Validate one schema against others.
- validate(Schema, Iterable<Schema>) - Method in class org.apache.avro.ValidateAll
- validate(Schema, Iterable<Schema>) - Method in class org.apache.avro.ValidateLatest
- 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
- validate(Schema, Schema) - Method in interface org.apache.avro.SchemaValidationStrategy
-
Validates that one schema is compatible with another.
- validateAll() - Method in class org.apache.avro.SchemaValidatorBuilder
- ValidateAll - Class in org.apache.avro
-
A
SchemaValidator
for validating the provided schema against all schemas in the Iterable inValidateAll.validate(Schema, Iterable)
. - ValidateAll(SchemaValidationStrategy) - Constructor for class org.apache.avro.ValidateAll
- validateLatest() - Method in class org.apache.avro.SchemaValidatorBuilder
- ValidateLatest - Class in org.apache.avro
-
A
SchemaValidator
for validating the provided schema against the firstSchema
in the iterable inValidateLatest.validate(Schema, Iterable)
. - ValidateLatest(SchemaValidationStrategy) - Constructor for class org.apache.avro.ValidateLatest
- validateRecordForCompilation(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
- 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. - validatingDefaults() - Method in class org.apache.avro.SchemaBuilder.FieldBuilder
-
Validate field default value during
SchemaBuilder.FieldBuilder.completeField(Schema, JsonNode)
. - 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
- ValidatingRecordTest - Class in org.apache.avro.perf.test.record
- ValidatingRecordTest() - Constructor for class org.apache.avro.perf.test.record.ValidatingRecordTest
- ValidatingRecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
- ValidatingRecordTest_encode_jmhTest - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_encode_jmhTest
- ValidatingRecordTest_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType
- ValidatingRecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B1
- ValidatingRecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B2
- ValidatingRecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_jmhType_B3
- ValidatingRecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType
- ValidatingRecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B1
- ValidatingRecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
- ValidatingRecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateDecode_jmhType_B3
- ValidatingRecordTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType
- ValidatingRecordTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B1
- ValidatingRecordTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
- ValidatingRecordTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.record.jmh_generated
- ValidatingRecordTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_TestStateEncode_jmhType_B3
- ValidatingRecordTest.TestStateDecode - Class in org.apache.avro.perf.test.record
- ValidatingRecordTest.TestStateEncode - Class in org.apache.avro.perf.test.record
- value - Variable in class org.apache.avro.idl.IdlParser.JsonPairContext
- value - Variable in class org.apache.avro.idl.IdlParser.SchemaPropertyContext
- value() - Method in class org.apache.avro.mapred.Pair
-
Get the value.
- value() - Element in annotation type org.apache.avro.reflect.AvroAliases
- value() - Element in annotation type org.apache.avro.reflect.AvroDefault
- value() - Element in annotation type org.apache.avro.reflect.AvroDoc
- value() - Element in annotation type org.apache.avro.reflect.AvroMeta.AvroMetas
- value() - Element in annotation type org.apache.avro.reflect.AvroMeta
- value() - Element in annotation type org.apache.avro.reflect.AvroName
- value() - Element in annotation type org.apache.avro.reflect.AvroSchema
-
The schema to use for this value.
- value() - Element in annotation type org.apache.avro.reflect.Union
-
The instantiable classes that compose this union.
- value() - Element in annotation type org.apache.avro.specific.FixedSize
-
The declared size of instances of classes with this annotation.
- 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.schema.SchemaVisitorAction
-
Returns the enum constant of this type with the specified name.
- 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.FastReaderBuilder.RecordReader.Stage
-
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.mapred.tether.TaskType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.avro.Resolver.Action.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.avro.Resolver.ErrorAction.ErrorType
-
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.avro.SchemaCompatibility.SchemaIncompatibilityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.avro.util.SchemaVisitor.SchemaVisitorAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.ReferenceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Restructure
-
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 - Variable in class org.apache.avro.Resolver.EnumAdjust
- values() - Static method in enum org.apache.avro.compiler.schema.SchemaVisitorAction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- 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.FastReaderBuilder.RecordReader.Stage
-
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.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.Resolver.Action.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.avro.Resolver.ErrorAction.ErrorType
-
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() - 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() - Static method in enum org.apache.avro.SchemaCompatibility.SchemaIncompatibilityType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.avro.util.SchemaVisitor.SchemaVisitorAction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.ReferenceType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Restructure
-
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.
- 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.
- valueType - Variable in class org.apache.avro.idl.IdlParser.MapTypeContext
- ValueType - Enum in org.apache.trevni
-
The datatypes that may be stored in a column.
- variableDeclaration - Variable in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- variableDeclaration() - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- variableDeclaration() - Method in class org.apache.avro.idl.IdlParser.FormalParameterContext
- variableDeclaration() - Method in class org.apache.avro.idl.IdlParser
- variableDeclaration(int) - Method in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- VariableDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.avro.idl.IdlParser.VariableDeclarationContext
- variableDeclarations - Variable in class org.apache.avro.idl.IdlParser.FieldDeclarationContext
- VARIANT_NAME_INLINE - Static variable in class org.apache.avro.JsonSchemaFormatterFactory
- VARIANT_NAME_PRETTY - Static variable in class org.apache.avro.JsonSchemaFormatterFactory
- velocityToolsClassesNames - Variable in class org.apache.avro.mojo.AbstractAvroMojo
-
The qualified names of classes which the plugin will look up, instantiate (through an empty constructor that must exist) and set up to be injected into Velocity templates by Avro compiler.
- 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.
- visit(Schema, SchemaVisitor<T>) - Static method in class org.apache.avro.compiler.schema.Schemas
-
depth first visit.
- visit(Schema, SchemaVisitor<T>) - Static method in class org.apache.avro.util.Schemas
-
Depth first visit.
- visitErrorNode(ErrorNode) - Method in class org.apache.avro.idl.IdlBaseListener
- visitNonTerminal(Schema) - Method in class org.apache.avro.compiler.schema.CloningVisitor
- visitNonTerminal(Schema) - Method in interface org.apache.avro.compiler.schema.SchemaVisitor
-
Invoked for schema with children before proceeding to visit the children.
- visitNonTerminal(Schema) - Method in class org.apache.avro.util.SchemaResolver.IsResolvedSchemaVisitor
- visitNonTerminal(Schema) - Method in class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- visitNonTerminal(Schema) - Method in interface org.apache.avro.util.SchemaVisitor
-
Invoked for schema with children before proceeding to visit the children.
- visitTerminal(TerminalNode) - Method in class org.apache.avro.idl.IdlBaseListener
- visitTerminal(Schema) - Method in class org.apache.avro.compiler.schema.CloningVisitor
- visitTerminal(Schema) - Method in interface org.apache.avro.compiler.schema.SchemaVisitor
-
Invoked for schemas that do not have "child" schemas (like string, int ...)
- visitTerminal(Schema) - Method in class org.apache.avro.util.SchemaResolver.IsResolvedSchemaVisitor
- visitTerminal(Schema) - Method in class org.apache.avro.util.SchemaResolver.ResolvingVisitor
- visitTerminal(Schema) - Method in interface org.apache.avro.util.SchemaVisitor
-
Invoked for schemas that do not have "child" schemas (like string, int …) or for a previously encountered schema with children, which will be treated as a terminal.
- VOCABULARY - Static variable in class org.apache.avro.idl.IdlLexer
- VOCABULARY - Static variable in class org.apache.avro.idl.IdlParser
- Void - Static variable in class org.apache.avro.idl.IdlLexer
- Void - Static variable in class org.apache.avro.idl.IdlParser
- Void() - Method in class org.apache.avro.idl.IdlParser.IdentifierContext
- Void() - Method in class org.apache.avro.idl.IdlParser.ResultTypeContext
W
- WEAK - Enum constant in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.ReferenceType
-
Use
WeakReferences
. - 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
- WHEN_NECESSARY - Enum constant in enum org.apache.avro.util.springframework.ConcurrentReferenceHashMap.Restructure
- 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.
- withClassPropEnabled(boolean) - Method in class org.apache.avro.io.FastReaderBuilder
- withCodec(String) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
-
Set the compression codec.
- withCodec(CodecFactory) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
-
Set the compression codec.
- withCompressionCodec(CompressionCodec) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Sets the compression codec to use if it is enabled.
- withCompressionType(SequenceFile.CompressionType) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Sets the type of compression.
- withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
-
Sets the configuration.
- withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
-
Sets the configuration.
- withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Reader.Options
-
Sets the Hadoop configuration.
- withConfiguration(Configuration) - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Sets the Hadoop configuration.
- withDataModel(GenericData) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
-
Set the data model.
- withDataModel(GenericData) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
-
Set the data model.
- 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.
- withKeyClassEnabled(boolean) - Method in class org.apache.avro.io.FastReaderBuilder
- 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.
- word - Variable in class org.apache.avro.idl.IdlParser.IdentifierContext
- write(byte[], int, int) - Method in class org.apache.avro.grpc.AvroInputStream.CountingOutputStream
- write(byte[], int, int) - Method in class org.apache.avro.util.ByteBufferOutputStream
- write(int) - Method in class org.apache.avro.grpc.AvroInputStream.CountingOutputStream
- write(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(D, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
- write(D, Encoder) - Method in interface org.apache.avro.io.DatumWriter
-
Write a datum.
- 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.data.Json.ObjectWriter
- write(Object, Encoder) - Method in class org.apache.avro.reflect.CustomEncoding
- write(Object, Encoder) - Method in class org.apache.avro.reflect.DateAsLongEncoding
- 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(ByteBuffer) - Method in class org.apache.avro.util.ByteBufferOutputStream
- write(K, V) - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
- write(AvroKey<K>, AvroValue<V>) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordWriter
- write(AvroKey<T>, NullWritable) - Method in class org.apache.avro.mapreduce.AvroKeyRecordWriter
- write(AvroKey<T>, NullWritable) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordWriter
- write(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Called to write data.
- write(Schema, Object, Encoder) - Method in class org.apache.avro.reflect.ReflectDatumWriter
- 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.BlockingDirectBinaryEncoder
- 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.BlockingDirectBinaryEncoder
- 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.netty.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(byte[]) - Method in class org.apache.avro.io.Encoder
-
Writes a byte string.
- writeBytes(byte[], int, int) - Method in class org.apache.avro.io.BinaryEncoder
- writeBytes(byte[], int, int) - Method in class org.apache.avro.io.Encoder
-
Write a byte string.
- writeBytes(byte[], int, int) - Method in class org.apache.avro.io.JsonEncoder
- writeBytes(byte[], int, int) - Method in class org.apache.avro.io.ValidatingEncoder
- writeBytes(Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Called to write a bytes.
- 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
- writeBytes(ByteBuffer) - Method in class org.apache.avro.io.BinaryEncoder
- writeBytes(ByteBuffer) - Method in class org.apache.avro.io.Encoder
-
Write a byte string.
- writeBytes(ByteBuffer) - Method in class org.apache.avro.io.JsonEncoder
- writeBytes(ByteBuffer) - Method in class org.apache.avro.io.ValidatingEncoder
- 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(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.generic.GenericDatumWriter
-
Called to write an enum value.
- 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
- writeExternal(ObjectOutput) - Method in class org.apache.avro.ipc.HandshakeRequest
- writeExternal(ObjectOutput) - Method in class org.apache.avro.ipc.HandshakeResponse
- writeExternal(ObjectOutput) - Method in class org.apache.avro.ipc.MD5
- writeExternal(ObjectOutput) - Method in exception class org.apache.avro.specific.SpecificExceptionBase
- writeExternal(ObjectOutput) - Method in class org.apache.avro.specific.SpecificFixed
- writeExternal(ObjectOutput) - Method in class org.apache.avro.specific.SpecificRecordBase
- writeExternal(ObjectOutput) - Method in class org.apache.avro.util.Utf8
- 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
- writeField(Object, Schema.Field, Encoder, Object) - Method in class org.apache.avro.specific.SpecificDatumWriter
- writeFixed(byte[]) - Method in class org.apache.avro.io.Encoder
-
A shorthand for writeFixed(bytes, 0, bytes.length)
- 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(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[], int, int) - Method in class org.apache.avro.io.JsonEncoder
- writeFixed(byte[], int, int) - Method in class org.apache.avro.io.ValidatingEncoder
- writeFixed(ByteBuffer) - Method in class org.apache.avro.io.BlockingBinaryEncoder
- writeFixed(ByteBuffer) - Method in class org.apache.avro.io.BufferedBinaryEncoder
- writeFixed(ByteBuffer) - Method in class org.apache.avro.io.Encoder
-
Writes a fixed from a ByteBuffer.
- writeFixed(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Called to write a fixed value.
- 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
- WriteFutureListener(Callback<List<ByteBuffer>>) - Constructor for class org.apache.avro.ipc.netty.NettyTransceiver.WriteFutureListener
-
Creates a WriteFutureListener that notifies the given callback if an error occurs writing data to the channel.
- writeIdlProtocol(Writer, JsonProperties, String, String, Collection<Schema>, Collection<Protocol.Message>) - Static method in class org.apache.avro.idl.IdlUtils
- writeIdlProtocol(Writer, Protocol) - Static method in class org.apache.avro.idl.IdlUtils
- writeIdlProtocol(Writer, Schema) - Static method in class org.apache.avro.idl.IdlUtils
- writeIdlSchema(Writer, Schema) - Static method in class org.apache.avro.idl.IdlUtils
- writeIdlSchemas(Writer, String, Collection<Schema>) - Static method in class org.apache.avro.idl.IdlUtils
- 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.BlockingDirectBinaryEncoder
- 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.BlockingDirectBinaryEncoder
- 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.avro.Resolver.Action
- writer - Variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
-
Trevni file writer
- Writer(SortedKeyValueFile.Writer.Options) - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
-
Creates a writer for a new file.
- Writer(AvroSequenceFile.Writer.Options) - Constructor for class org.apache.avro.hadoop.io.AvroSequenceFile.Writer
-
Creates a new
Writer
to a SequenceFile that supports Avro data. - WRITER_UNION - Enum constant in enum org.apache.avro.Resolver.Action.Type
- WRITER_UNION_ACTION - Static variable in class org.apache.avro.io.parsing.Symbol
- writeRecord(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Called to write a record.
- writeRecord(Schema, Object, Encoder) - Method in class org.apache.avro.specific.SpecificDatumWriter
- writeReplace() - Method in class org.apache.avro.Schema
- 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
- writeStats(Writer) - Method in class org.apache.avro.ipc.stats.StatsServlet
- writeString(CharSequence) - Method in class org.apache.avro.io.Encoder
-
Write a Unicode character string.
- writeString(CharSequence) - Method in class org.apache.avro.io.ValidatingEncoder
- writeString(Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Called to write a string.
- writeString(String) - Method in class org.apache.avro.io.BinaryEncoder
- writeString(String) - Method in class org.apache.avro.io.Encoder
-
Write a Unicode character string.
- writeString(String) - Method in class org.apache.avro.io.JsonEncoder
- writeString(String) - Method in class org.apache.avro.io.ValidatingEncoder
- writeString(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Called to write a string.
- writeString(Schema, Object, Encoder) - Method in class org.apache.avro.specific.SpecificDatumWriter
- writeString(Utf8) - Method in class org.apache.avro.io.BinaryEncoder
- writeString(Utf8) - Method in class org.apache.avro.io.Encoder
-
Write a Unicode character string.
- writeString(Utf8) - Method in class org.apache.avro.io.JsonEncoder
- writeString(Utf8) - Method in class org.apache.avro.io.ValidatingEncoder
- 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.avro.AvroColumnWriter
-
Write all rows added to the named output stream.
- 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.
- writeWithoutConversion(Schema, Object, Encoder) - Method in class org.apache.avro.generic.GenericDatumWriter
-
Called to write data.
- 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
- WS - Static variable in class org.apache.avro.idl.IdlLexer
- WS - Static variable in class org.apache.avro.idl.IdlParser
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. compressionLevel should be between 1 and 9, inclusive.
- XZCodec - Class in org.apache.avro.file
-
Implements xz compression and decompression.
- XZCodec(int) - Constructor for class org.apache.avro.file.XZCodec
Z
- ZSTANDARD_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
- zstandardCodec(int) - Static method in class org.apache.avro.file.CodecFactory
-
zstandard codec, with specific compression level.
- zstandardCodec(int, boolean) - Static method in class org.apache.avro.file.CodecFactory
-
zstandard codec, with specific compression level.
- zstandardCodec(int, boolean, boolean) - Static method in class org.apache.avro.file.CodecFactory
-
zstandard codec, with specific compression level, checksum, and bufferPool
- ZstandardCodec - Class in org.apache.avro.file
- ZstandardCodec(int, boolean, boolean) - Constructor for class org.apache.avro.file.ZstandardCodec
-
Create a ZstandardCodec instance with the given compressionLevel, checksum, and bufferPool option
- ZSTD_BUFFERPOOL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
-
The configuration key for Avro ZSTD buffer pool.
- ZSTD_LEVEL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
-
The configuration key for Avro ZSTD level.
_
- _ATN - Static variable in class org.apache.avro.idl.IdlLexer
- _ATN - Static variable in class org.apache.avro.idl.IdlParser
- _decisionToDFA - Static variable in class org.apache.avro.idl.IdlLexer
- _decisionToDFA - Static variable in class org.apache.avro.idl.IdlParser
- _serializedATN - Static variable in class org.apache.avro.idl.IdlLexer
- _serializedATN - Static variable in class org.apache.avro.idl.IdlParser
- _sharedContextCache - Static variable in class org.apache.avro.idl.IdlLexer
- _sharedContextCache - Static variable in class org.apache.avro.idl.IdlParser
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form