- abort() - Method in interface org.apache.avro.mapred.tether.InputProtocol
-
Transmit inputs to a map or reduce task sub-process.
- 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
-
- 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(int, T) - Method in class org.apache.avro.generic.GenericData.Array
-
- addAlias(String) - Method in class org.apache.avro.Schema
-
If this is a record, enum or fixed, add an alias.
- addAlias(String, String) - Method in class org.apache.avro.Schema
-
If this is a record, enum or fixed, add an alias.
- addAlias(String) - Method in class org.apache.avro.Schema.Field
-
- 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 org.apache.avro.AvroMissingFieldException
-
- addProp(String, String) - Method in class org.apache.avro.JsonProperties
-
Adds a property with the given name name and value value.
- addProp(String, Object) - Method in class org.apache.avro.JsonProperties
-
- addProp(String, String) - Method in class org.apache.avro.Schema
-
- addProp(String, Object) - 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.
- addToArray(Object, long, Object) - Method in class org.apache.avro.generic.GenericDatumReader
-
- addToArray(Object, long, Object) - Method in class org.apache.avro.reflect.ReflectDatumReader
-
- addToConfiguration(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
-
Adds the AvroSerialization scheme to the configuration, so
SerializationFactory instances constructed from the given configuration will
be aware of it.
- addToMap(Object, Object, Object) - Method in class org.apache.avro.generic.GenericDatumReader
-
- 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(Map<String, Schema>) - Method in class org.apache.avro.Schema.Parser
-
Adds the provided types to the set of defined, named types known to this
parser.
- 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
-
- 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.
- 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
-
- 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(K, V) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer
-
Appends a record to the SortedKeyValueFile.
- append(List<ByteBuffer>) - Method in class org.apache.avro.util.ByteBufferOutputStream
-
Append a list of ByteBuffers to this stream.
- appendAllFrom(DataFileStream<D>, boolean) - Method in class org.apache.avro.file.DataFileWriter
-
Appends data from another file.
- appendEncoded(ByteBuffer) - Method in class org.apache.avro.file.DataFileWriter
-
Expert: Append a pre-encoded datum to the file.
- appendTo(File) - Method in class org.apache.avro.file.DataFileWriter
-
Open a writer appending to an existing file.
- appendTo(SeekableInput, OutputStream) - Method in class org.apache.avro.file.DataFileWriter
-
Open a writer appending to an existing file.
- AppendWriteException(Exception) - Constructor for exception 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(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() - Static method in class org.apache.avro.SchemaBuilder
-
Create a builder for an Avro array This is equivalent to:
- array() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
Build an Avro array type
- array() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
Build an Avro array type Example usage:
- array() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
Build an Avro array type
- ARRAY_END - Static variable in class org.apache.avro.io.parsing.Symbol
-
- ARRAY_START - Static variable in class org.apache.avro.io.parsing.Symbol
-
- 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
-
- 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.TestStateDecode - Class in org.apache.avro.perf.test.basic
-
- ArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
-
- ArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_decode_jmhTest
-
- ArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_encode_jmhTest
-
- ArrayTest_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType
-
- ArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B1
-
- ArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B2
-
- ArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B3
-
- ArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType
-
- ArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B1
-
- ArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B2
-
- ArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B3
-
- ArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType
-
- ArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B1
-
- ArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B2
-
- ArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- ArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B3
-
- 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
-
- 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 extends AvroWrapper<D>,D> - Class in org.apache.avro.hadoop.io
-
Deserializes AvroWrapper objects within Hadoop.
- AvroDeserializer(Schema, Schema, ClassLoader) - Constructor for class org.apache.avro.hadoop.io.AvroDeserializer
-
Constructor.
- AvroDeserializer(Schema, Schema, DatumReader<D>) - Constructor for class org.apache.avro.hadoop.io.AvroDeserializer
-
Constructor.
- 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
-
- AvroInputFormat() - Constructor for class org.apache.avro.mapred.AvroInputFormat
-
- AvroInputStream - Class in org.apache.avro.grpc
-
- AvroInputStream() - Constructor for class org.apache.avro.grpc.AvroInputStream
-
- AvroInputStream.CountingOutputStream - Class in org.apache.avro.grpc
-
- 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
-
- AvroKeyComparator() - Constructor for class org.apache.avro.hadoop.io.AvroKeyComparator
-
- AvroKeyComparator<T> - Class in org.apache.avro.mapred
-
- AvroKeyComparator() - Constructor for class org.apache.avro.mapred.AvroKeyComparator
-
- AvroKeyDeserializer<D> - Class in org.apache.avro.hadoop.io
-
Deserializes AvroKey objects within Hadoop.
- AvroKeyDeserializer(Schema, Schema, ClassLoader) - Constructor for class org.apache.avro.hadoop.io.AvroKeyDeserializer
-
Constructor.
- AvroKeyDeserializer(Schema, Schema, DatumReader<D>) - Constructor for class org.apache.avro.hadoop.io.AvroKeyDeserializer
-
Constructor.
- AvroKeyInputFormat<T> - Class in org.apache.avro.mapreduce
-
A MapReduce InputFormat that can handle Avro container files.
- AvroKeyInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyInputFormat
-
- AvroKeyOutputFormat<T> - Class in org.apache.avro.mapreduce
-
FileOutputFormat for writing Avro container files.
- AvroKeyOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat
-
Constructor.
- AvroKeyOutputFormat(AvroKeyOutputFormat.RecordWriterFactory) - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat
-
Constructor.
- AvroKeyOutputFormat.RecordWriterFactory<T> - Class in org.apache.avro.mapreduce
-
A factory for creating record writers.
- AvroKeyRecordReader<T> - Class in org.apache.avro.mapreduce
-
Reads records from an input split representing a chunk of an Avro container
file.
- AvroKeyRecordReader(Schema) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordReader
-
Constructor.
- AvroKeyRecordWriter<T> - Class in org.apache.avro.mapreduce
-
Writes Avro records to an Avro container file output stream.
- AvroKeyRecordWriter(Schema, GenericData, CodecFactory, OutputStream, int) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordWriter
-
Constructor.
- AvroKeyRecordWriter(Schema, GenericData, CodecFactory, OutputStream) - Constructor for class org.apache.avro.mapreduce.AvroKeyRecordWriter
-
Constructor.
- AvroKeyValue<K,V> - Class in org.apache.avro.hadoop.io
-
A helper object for working with the Avro generic records that are used to
store key/value pairs in an Avro container file.
- AvroKeyValue(GenericRecord) - Constructor for class org.apache.avro.hadoop.io.AvroKeyValue
-
Wraps a GenericRecord that is a key value pair.
- AvroKeyValue.Iterator<K,V> - Class in org.apache.avro.hadoop.io
-
A wrapper for iterators over GenericRecords that are known to be KeyValue
records.
- AvroKeyValueInputFormat<K,V> - Class in org.apache.avro.mapreduce
-
A MapReduce InputFormat that reads from Avro container files of key/value
generic records.
- AvroKeyValueInputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyValueInputFormat
-
- AvroKeyValueOutputFormat<K,V> - Class in org.apache.avro.mapreduce
-
FileOutputFormat for writing Avro container files of key/value pairs.
- AvroKeyValueOutputFormat() - Constructor for class org.apache.avro.mapreduce.AvroKeyValueOutputFormat
-
- AvroKeyValueRecordReader<K,V> - Class in org.apache.avro.mapreduce
-
Reads Avro generic records from an Avro container file, where the records
contain two fields: 'key' and 'value'.
- AvroKeyValueRecordReader(Schema, Schema) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordReader
-
Constructor.
- AvroKeyValueRecordWriter<K,V> - Class in org.apache.avro.mapreduce
-
Writes key/value pairs to an Avro container file.
- AvroKeyValueRecordWriter(AvroDatumConverter<K, ?>, AvroDatumConverter<V, ?>, GenericData, CodecFactory, OutputStream, int) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
-
Constructor.
- AvroKeyValueRecordWriter(AvroDatumConverter<K, ?>, AvroDatumConverter<V, ?>, GenericData, CodecFactory, OutputStream) - Constructor for class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
-
Constructor.
- AvroMapper<IN,OUT> - Class in org.apache.avro.mapred
-
A mapper for Avro data.
- AvroMapper() - Constructor for class org.apache.avro.mapred.AvroMapper
-
- 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 in org.apache.avro
-
Avro exception in case of missing fields.
- AvroMissingFieldException(String, Schema.Field) - Constructor for exception 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
and
AvroMapper
for each path.
- AvroMultipleInputs() - Constructor for class org.apache.avro.mapred.AvroMultipleInputs
-
- AvroMultipleOutputs - Class in org.apache.avro.mapred
-
The AvroMultipleOutputs class simplifies writing Avro output data to multiple
outputs
- AvroMultipleOutputs(JobConf) - Constructor for class org.apache.avro.mapred.AvroMultipleOutputs
-
Creates and initializes multiple named outputs support, it should be
instantiated in the Mapper/Reducer configure method.
- AvroMultipleOutputs - Class in org.apache.avro.mapreduce
-
The AvroMultipleOutputs class simplifies writing Avro output data to multiple
outputs
- AvroMultipleOutputs(TaskInputOutputContext<?, ?, ?, ?>) - Constructor for class org.apache.avro.mapreduce.AvroMultipleOutputs
-
Creates and initializes multiple outputs support, it should be instantiated
in the Mapper/Reducer setup method.
- AvroName - Annotation Type in org.apache.avro.reflect
-
Sets the avroname for this java field.
- AvroOutputFormat<T> - Class in org.apache.avro.mapred
-
- 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
-
- AvroRecordReader(JobConf, FileSplit) - Constructor for class org.apache.avro.mapred.AvroRecordReader
-
- AvroRecordReader(FileReader<T>, FileSplit) - Constructor for class org.apache.avro.mapred.AvroRecordReader
-
- AvroRecordReaderBase<K,V,T> - Class in org.apache.avro.mapreduce
-
Abstract base class for RecordReader
s that read Avro container
files.
- AvroRecordReaderBase(Schema) - Constructor for class org.apache.avro.mapreduce.AvroRecordReaderBase
-
Constructor.
- AvroReducer<K,V,OUT> - Class in org.apache.avro.mapred
-
A reducer for Avro data.
- AvroReducer() - Constructor for class org.apache.avro.mapred.AvroReducer
-
- AvroRemoteException - Exception in org.apache.avro
-
Base class for exceptions thrown to client by server.
- AvroRemoteException() - Constructor for exception org.apache.avro.AvroRemoteException
-
- AvroRemoteException(Throwable) - Constructor for exception org.apache.avro.AvroRemoteException
-
- AvroRemoteException(Object) - Constructor for exception org.apache.avro.AvroRemoteException
-
- AvroRemoteException(Object, Throwable) - Constructor for exception org.apache.avro.AvroRemoteException
-
- 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 in org.apache.avro
-
Base Avro exception.
- AvroRuntimeException(Throwable) - Constructor for exception org.apache.avro.AvroRuntimeException
-
- AvroRuntimeException(String) - Constructor for exception org.apache.avro.AvroRuntimeException
-
- AvroRuntimeException(String, Throwable) - Constructor for exception org.apache.avro.AvroRuntimeException
-
- AvroSchema - Annotation Type in org.apache.avro.reflect
-
Declares that a Java type should have a specified Avro schema, overriding the
normally inferred schema.
- AvroSequenceFile - Class in org.apache.avro.hadoop.io
-
A wrapper around a Hadoop
SequenceFile
that also
supports reading and writing Avro data.
- AvroSequenceFile.Reader - Class in org.apache.avro.hadoop.io
-
A reader for SequenceFiles that may contain Avro data.
- AvroSequenceFile.Reader.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
-
- AvroSerialization() - Constructor for class org.apache.avro.hadoop.io.AvroSerialization
-
- AvroSerialization<T> - Class in org.apache.avro.mapred
-
- 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
-
- AvroTrevniInputFormat() - Constructor for class org.apache.trevni.avro.AvroTrevniInputFormat
-
- AvroTrevniKeyInputFormat<T> - Class in org.apache.trevni.avro.mapreduce
-
- AvroTrevniKeyInputFormat() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyInputFormat
-
- AvroTrevniKeyOutputFormat<T> - Class in org.apache.trevni.avro.mapreduce
-
- 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
-
- AvroTrevniKeyValueInputFormat() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueInputFormat
-
- AvroTrevniKeyValueOutputFormat<K,V> - Class in org.apache.trevni.avro.mapreduce
-
- 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
-
- AvroTrevniOutputFormat() - Constructor for class org.apache.trevni.avro.AvroTrevniOutputFormat
-
- AvroTrevniRecordReaderBase<K,V,T> - Class in org.apache.trevni.avro.mapreduce
-
Abstract base class for RecordReader
s that read Trevni container
files.
- AvroTrevniRecordReaderBase() - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
-
- AvroTrevniRecordWriterBase<K,V,T> - Class in org.apache.trevni.avro.mapreduce
-
Abstract base class for RecordWriter
s that writes Trevni
container files.
- AvroTrevniRecordWriterBase(TaskAttemptContext) - Constructor for class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
-
Constructor.
- AvroTypeException - Exception in org.apache.avro
-
Thrown when an illegal type is used.
- AvroTypeException(String) - Constructor for exception org.apache.avro.AvroTypeException
-
- AvroTypeException(String, Throwable) - Constructor for exception org.apache.avro.AvroTypeException
-
- AvroUtf8InputFormat - Class in org.apache.avro.mapred
-
- 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.
- 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.
- Callback<T> - Interface in org.apache.avro.ipc
-
Interface for receiving asynchronous callbacks.
- callback - Variable in class org.apache.avro.ipc.netty.NettyTransceiver.WriteFutureListener
-
- CallFuture<T> - Class in org.apache.avro.ipc
-
A Future implementation for RPCs.
- CallFuture() - Constructor for class org.apache.avro.ipc.CallFuture
-
Creates a CallFuture.
- CallFuture(Callback<T>) - Constructor for class org.apache.avro.ipc.CallFuture
-
Creates a CallFuture with a chained Callback which will be invoked when this
CallFuture's Callback methods are invoked.
- 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
-
- 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
-
- channelRead0(ChannelHandlerContext, NettyTransportCodec.NettyDataPack) - Method in class org.apache.avro.ipc.netty.NettyTransceiver.NettyClientAvroHandler
-
- charAt(int) - Method in class org.apache.avro.util.Utf8
-
- charts - Variable in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
-
- checkReaderWriterCompatibility(Schema, Schema) - Static method in class org.apache.avro.SchemaCompatibility
-
Validates that the provided reader schema can be used to decode avro data
written with the provided writer schema.
- CLASS_PROP - Static variable in class org.apache.avro.specific.SpecificData
-
- ClassUtils - Class in org.apache.avro.util
-
- clear() - Method in class org.apache.avro.generic.GenericData.Array
-
- clear(String) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Clears the value of the given field.
- clear(Schema.Field) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Clears the value of the given field.
- clear(int) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Clears the value of the given field.
- clear() - Method in class org.apache.avro.util.WeakIdentityHashMap
-
- clearCause() - Method in interface org.apache.avro.data.ErrorBuilder
-
Clears the cause
- clearCause() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
-
- clearClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Clears the value of the 'clientHash' field.
- clearClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Clears the value of the 'clientProtocol' field.
- 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
-
- 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.
- CloningVisitor(Schema) - Constructor for class org.apache.avro.compiler.schema.CloningVisitor
-
copy only serialization necessary fields.
- CloningVisitor(CloningVisitor.PropertyCopier, boolean, Schema) - Constructor for class org.apache.avro.compiler.schema.CloningVisitor
-
- 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(boolean) - 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(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyRecordWriter
- close(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
- close() - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
-
Closes all the opened outputs.
- close() - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
- close() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
- close() - Method in class org.apache.trevni.avro.AvroColumnReader
-
- close() - Method in class org.apache.trevni.avro.HadoopInput
-
- close() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
- close(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
- close() - Method in class org.apache.trevni.ColumnFileReader
-
- close() - Method in class org.apache.trevni.InputFile
-
- Codec - Class in org.apache.avro.file
-
Interface for Avro-supported compression codecs for data files.
- Codec() - Constructor for class org.apache.avro.file.Codec
-
- CODEC - Static variable in class org.apache.avro.file.DataFileConstants
-
- CodecFactory - Class in org.apache.avro.file
-
Encapsulates the ability to specify and configure a compression codec.
- CodecFactory() - Constructor for class org.apache.avro.file.CodecFactory
-
- collect(T) - Method in class org.apache.avro.mapred.AvroCollector
-
- collect(String, Reporter, Object) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
-
Output Collector for the default schema.
- collect(String, Reporter, Schema, Object) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
-
OutputCollector with custom schema.
- collect(String, Reporter, Schema, Object, String) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
-
OutputCollector with custom schema and file name.
- ColumnFileMetaData - Class in org.apache.trevni
-
File-level metadata.
- ColumnFileMetaData() - Constructor for class org.apache.trevni.ColumnFileMetaData
-
- ColumnFileReader - Class in org.apache.trevni
-
Reads data from a column file.
- ColumnFileReader(File) - Constructor for class org.apache.trevni.ColumnFileReader
-
Construct reading from the named file.
- ColumnFileReader(Input) - Constructor for class org.apache.trevni.ColumnFileReader
-
Construct reading from the provided input.
- ColumnFileWriter - Class in org.apache.trevni
-
Writes data to a column file.
- ColumnFileWriter(ColumnFileMetaData, ColumnMetaData...) - Constructor for class org.apache.trevni.ColumnFileWriter
-
Construct given metadata for each column in the file.
- ColumnMetaData - Class in org.apache.trevni
-
Metadata for a column.
- ColumnMetaData(String, ValueType) - Constructor for class org.apache.trevni.ColumnMetaData
-
Construct given a name and type.
- ColumnValues<T extends Comparable> - Class in org.apache.trevni
-
An iterator over column values.
- CombineAvroKeyValueFileInputFormat<K,V> - Class in org.apache.avro.mapreduce
-
A combine avro keyvalue file input format that can combine small avro files
into mappers.
- CombineAvroKeyValueFileInputFormat() - Constructor for class org.apache.avro.mapreduce.CombineAvroKeyValueFileInputFormat
-
- compare(Object, Object, Schema) - Method in class org.apache.avro.generic.GenericData
-
Compare objects according to their schema.
- compare(Object, Object, Schema, boolean) - Method in class org.apache.avro.generic.GenericData
-
Comparison implementation.
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
- compare(AvroKey<T>, AvroKey<T>) - Method in class org.apache.avro.hadoop.io.AvroKeyComparator
- compare(T, T) - Method in class org.apache.avro.hadoop.util.AvroCharSequenceComparator
- compare(byte[], int, byte[], int, Schema) - Static method in class org.apache.avro.io.BinaryData
-
Compare binary encoded data.
- compare(byte[], int, int, byte[], int, int, Schema) - Static method in class org.apache.avro.io.BinaryData
-
Compare binary encoded data.
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.avro.mapred.AvroKeyComparator
-
- compare(AvroWrapper<T>, AvroWrapper<T>) - Method in class org.apache.avro.mapred.AvroKeyComparator
-
- compare(Object, Object, Schema, boolean) - Method in class org.apache.avro.reflect.ReflectData
-
- compare(Object, Object, Schema, boolean) - Method in class org.apache.avro.specific.SpecificData
-
- compareBytes(byte[], int, int, byte[], int, int) - Static method in class org.apache.avro.io.BinaryData
-
Lexicographically compare bytes.
- compareTo(GenericArray<T>) - Method in class org.apache.avro.generic.GenericData.Array
-
- compareTo(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.
- compileProtocol(File, File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java interface and classes for a protocol.
- compileProtocol(File[], File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java interface and classes for a number of protocol files.
- compileSchema(File, File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java classes for a schema.
- compileSchema(File[], File) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates Java classes for a number of schema files.
- compileToDestination(File, File) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generate output under dst, unless existing file is newer than src.
- complete() - Method in interface org.apache.avro.mapred.tether.InputProtocol
-
Transmit inputs to a map or reduce task sub-process.
- complete() - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Transmit outputs from a map or reduce task to parent.
- 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
-
- computeOffset(ByteBuffer) - Static method in class org.apache.avro.file.Codec
-
- ConcatTool - Class in org.apache.avro.tool
-
Tool to concatenate avro files with the same schema and non-reserved
metatdata.
- ConcatTool() - Constructor for class org.apache.avro.tool.ConcatTool
-
- CONF_OUTPUT_CODEC - Static variable in class org.apache.avro.mapreduce.AvroJob
-
The configuration key for a job's output compression codec.
- configure(InputStream) - Method in class org.apache.avro.io.JsonDecoder
-
Reconfigures this JsonDecoder to use the InputStream provided.
- configure(String) - Method in class org.apache.avro.io.JsonDecoder
-
Reconfigures this JsonDecoder to use the String provided for input.
- configure(OutputStream) - Method in class org.apache.avro.io.JsonEncoder
-
Reconfigures this JsonEncoder to use the output stream provided.
- configure(Decoder) - Method in class org.apache.avro.io.ValidatingDecoder
-
Re-initialize, reading from a new underlying Decoder.
- configure(Encoder) - Method in class org.apache.avro.io.ValidatingEncoder
-
Reconfigures this ValidatingEncoder to wrap the encoder provided.
- configure(JobConf) - Method in class org.apache.avro.mapred.AvroMapper
-
Subclasses can override this as desired.
- configure(JobConf) - Method in class org.apache.avro.mapred.AvroReducer
-
Subclasses can override this as desired.
- configure(JobConf) - Method in class org.apache.avro.mapred.AvroUtf8InputFormat
-
- configure(TaskType, String, String) - Method in interface org.apache.avro.mapred.tether.InputProtocol
-
Transmit inputs to a map or reduce task sub-process.
- configure(int) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Transmit outputs from a map or reduce task to parent.
- 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
-
- 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
-
- Conversion<T> - Class in org.apache.avro
-
Conversion between generic and logical type instances.
- Conversion() - Constructor for class org.apache.avro.Conversion
-
- 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.
- 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.DecimalConversion - Class in org.apache.avro
-
- Conversions.UUIDConversion - Class in org.apache.avro
-
- convert(Object, Schema, LogicalType, Conversion<?>) - Method in class org.apache.avro.generic.GenericDatumReader
-
Convert a underlying representation of a logical type (such as a ByteBuffer)
to a higher level object (such as a BigDecimal).
- 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 the its underlying representation object (such as a ByteBuffer).
- convert(INPUT) - Method in class org.apache.avro.hadoop.io.AvroDatumConverter
-
- convert(AvroWrapper<?>) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.AvroWrapperConverter
- convert(BooleanWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BooleanWritableConverter
- convert(BytesWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.BytesWritableConverter
- convert(ByteWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.ByteWritableConverter
- convert(DoubleWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.DoubleWritableConverter
- convert(FloatWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.FloatWritableConverter
- convert(IntWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.IntWritableConverter
- convert(LongWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.LongWritableConverter
- convert(NullWritable) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.NullWritableConverter
- convert(Text) - Method in class org.apache.avro.hadoop.io.AvroDatumConverterFactory.TextConverter
- convertToLogicalType(Object, Schema, LogicalType, Conversion<?>) - Static method in class org.apache.avro.Conversions
-
Convert a 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 the its underlying representation object (such as a ByteBuffer)
- copy(Schema, Schema) - Method in interface org.apache.avro.compiler.schema.CloningVisitor.PropertyCopier
-
- copy(Schema.Field, Schema.Field) - Method in interface org.apache.avro.compiler.schema.CloningVisitor.PropertyCopier
-
- copyAliases(Schema, Schema) - Static method in class org.apache.avro.compiler.schema.Schemas
-
- copyAliases(Schema.Field, Schema.Field) - 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
-
- count(String, String, long) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Transmit outputs from a map or reduce task to parent.
- CountingOutputStream(OutputStream) - Constructor for class org.apache.avro.grpc.AvroInputStream.CountingOutputStream
-
- 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(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, GenericData, CodecFactory, OutputStream, int) - Method in class org.apache.avro.mapreduce.AvroKeyOutputFormat.RecordWriterFactory
-
Creates a new record writer instance.
- create(Schema.Type) - Static method in class org.apache.avro.Schema
-
Create a schema for a primitive type.
- createArray(Schema) - Static method in class org.apache.avro.Schema
-
Create an array schema.
- createAvroFileReader(SeekableInput, DatumReader<T>) - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
-
Creates an Avro container file reader from a seekable input stream.
- createAvroWrapper() - Method in class org.apache.avro.hadoop.io.AvroDeserializer
-
Creates a new empty T
(extends AvroWrapper) instance.
- createAvroWrapper() - Method in class org.apache.avro.hadoop.io.AvroKeyDeserializer
-
Creates a new empty AvroKey
instance.
- createAvroWrapper() - Method in class org.apache.avro.hadoop.io.AvroValueDeserializer
-
Creates a new empty AvroValue
instance.
- createBinaryDecoder(InputStream, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
-
- createBinaryDecoder(byte[], int, int, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
-
- createBinaryDecoder(byte[], BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
-
- createBytes(byte[]) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to create byte arrays from default values.
- 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
-
- createDatumReader(Schema, Schema) - Method in class org.apache.avro.generic.GenericData
-
- createDatumReader(Schema) - Method in class org.apache.avro.io.FastReaderBuilder
-
- createDatumReader(Schema, 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, Schema) - Method in class org.apache.avro.reflect.ReflectData
-
- createDatumReader(Schema) - Method in class org.apache.avro.specific.SpecificData
-
- createDatumReader(Schema, Schema) - Method in class org.apache.avro.specific.SpecificData
-
- createDatumReader(Schema) - Method in class org.apache.avro.thrift.ThriftData
-
- createDatumWriter(Schema) - Method in class org.apache.avro.generic.GenericData
-
- 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, Schema) - Method in class org.apache.avro.generic.GenericData
-
Called to create an enum value.
- createEnum(String, Schema) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to create an enum value.
- createEnum(String, Schema) - Method in class org.apache.avro.protobuf.ProtobufDatumReader
-
- createEnum(String, String, String, List<String>) - Static method in class org.apache.avro.Schema
-
Create an enum schema.
- createEnum(String, 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.specific.SpecificData
-
- createEnum(String, Schema) - Method in class org.apache.avro.thrift.ThriftDatumReader
-
- createFieldSchema(Field, Map<String, Schema>) - Method in class org.apache.avro.reflect.ReflectData.AllowNull
-
- createFieldSchema(Field, Map<String, Schema>) - Method in class org.apache.avro.reflect.ReflectData
-
Create a schema for a field.
- createFixed(Object, Schema) - Method in class org.apache.avro.generic.GenericData
-
Called to create an fixed value.
- createFixed(Object, byte[], Schema) - Method in class org.apache.avro.generic.GenericData
-
Called to create an fixed value.
- createFixed(Object, Schema) - Method in class org.apache.avro.generic.GenericDatumReader
-
- createFixed(Object, byte[], Schema) - Method in class org.apache.avro.generic.GenericDatumReader
-
- createFixed(Object, Schema) - Method in class org.apache.avro.reflect.ReflectData
-
- createFixed(String, String, String, int) - Static method in class org.apache.avro.Schema
-
Create a fixed schema.
- createFixed(Object, Schema) - Method in class org.apache.avro.specific.SpecificData
-
- createInputDataModel(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
-
- createInstance() - Method in class org.apache.avro.file.CodecFactory
-
Creates internal Codec.
- createKey() - Method in class org.apache.avro.mapred.AvroRecordReader
-
- createMap(Schema) - Static method in class org.apache.avro.Schema
-
Create a map schema.
- createMapOutputDataModel(Configuration) - Static method in class org.apache.avro.mapred.AvroJob
-
- createMessage(String, String, Schema) - Method in class org.apache.avro.Protocol
-
Deprecated.
- createMessage(Protocol.Message, Schema) - Method in class org.apache.avro.Protocol
-
Create a one-way message using the name
, doc
, and
props
of m
.
- createMessage(String, String, JsonProperties, Schema) - Method in class org.apache.avro.Protocol
-
Create a one-way message.
- createMessage(String, String, Map<String, ?>, Schema) - Method in class org.apache.avro.Protocol
-
Create a one-way message.
- createMessage(String, String, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Deprecated.
- createMessage(Protocol.Message, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Create a two-way message using the name
, doc
, and
props
of m
.
- createMessage(String, String, JsonProperties, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Create a two-way message.
- createMessage(String, String, Map<String, ?>, Schema, Schema, Schema) - Method in class org.apache.avro.Protocol
-
Create a two-way message.
- createNettyClientAvroHandler() - Method in class org.apache.avro.ipc.netty.NettyTransceiver
-
Creates a Netty ChannelUpstreamHandler for handling events on the Netty
client channel.
- 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(List<Schema.Field>) - Static method in class org.apache.avro.Schema
-
- 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.
- 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
- 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(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
-
- createString(Object) - Method in class org.apache.avro.specific.SpecificData
-
- 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
-
- generate(Schema) - Method in class org.apache.avro.io.parsing.JsonGrammarGenerator
-
Returns the non-terminal that is the start symbol for the grammar for the
grammar for the given schema sc.
- generate(Schema, Map<ValidatingGrammarGenerator.LitS, Symbol>) - Method in class org.apache.avro.io.parsing.JsonGrammarGenerator
-
Returns the non-terminal that is the start symbol for grammar of the given
schema sc.
- generate(Schema, Schema) - Method in class org.apache.avro.io.parsing.ResolvingGrammarGenerator
-
Resolves the writer schema writer and the reader schema
reader and returns the start symbol for the grammar generated.
- generate(Schema) - Method in class org.apache.avro.io.parsing.ValidatingGrammarGenerator
-
Returns the non-terminal that is the start symbol for the grammar for the
given schema sc.
- generate(Schema, Map<ValidatingGrammarGenerator.LitS, Symbol>) - Method in class org.apache.avro.io.parsing.ValidatingGrammarGenerator
-
Returns the non-terminal that is the start symbol for the grammar for the
given schema sc.
- generateClearMethod(Schema, Schema.Field) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Generates the name of a field "clear" method.
- 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.Array<T> - Class in org.apache.avro.generic
-
Default implementation of an array.
- GenericData.EnumSymbol - Class in org.apache.avro.generic
-
- GenericData.Fixed - Class in org.apache.avro.generic
-
- GenericData.InstanceSupplier - Interface in org.apache.avro.generic
-
- GenericData.Record - Class in org.apache.avro.generic
-
- 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
-
- GenericDatumReader() - Constructor for class org.apache.avro.generic.GenericDatumReader
-
- GenericDatumReader(Schema) - Constructor for class org.apache.avro.generic.GenericDatumReader
-
Construct where the writer's and reader's schemas are the same.
- GenericDatumReader(Schema, Schema) - Constructor for class org.apache.avro.generic.GenericDatumReader
-
Construct given writer's and reader's schema.
- GenericDatumReader(Schema, Schema, GenericData) - Constructor for class org.apache.avro.generic.GenericDatumReader
-
- GenericDatumReader(GenericData) - Constructor for class org.apache.avro.generic.GenericDatumReader
-
- GenericDatumWriter<D> - Class in org.apache.avro.generic
-
- 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 extends 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.TestStateDecode - Class in org.apache.avro.perf.test.generic
-
- GenericNestedFakeTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
-
- GenericNestedFakeTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_decode_jmhTest
-
- GenericNestedFakeTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_encode_jmhTest
-
- GenericNestedFakeTest_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType
-
- GenericNestedFakeTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B1
-
- GenericNestedFakeTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B2
-
- GenericNestedFakeTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B3
-
- GenericNestedFakeTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType
-
- GenericNestedFakeTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B1
-
- GenericNestedFakeTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
-
- GenericNestedFakeTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B3
-
- GenericNestedFakeTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType
-
- GenericNestedFakeTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B1
-
- GenericNestedFakeTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
-
- GenericNestedFakeTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedFakeTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B3
-
- GenericNestedTest - Class in org.apache.avro.perf.test.generic
-
- GenericNestedTest() - Constructor for class org.apache.avro.perf.test.generic.GenericNestedTest
-
- GenericNestedTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
-
- GenericNestedTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
-
- GenericNestedTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_decode_jmhTest
-
- GenericNestedTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_encode_jmhTest
-
- GenericNestedTest_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType
-
- GenericNestedTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B1
-
- GenericNestedTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B2
-
- GenericNestedTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B3
-
- GenericNestedTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType
-
- GenericNestedTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B1
-
- GenericNestedTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B2
-
- GenericNestedTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B3
-
- GenericNestedTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType
-
- GenericNestedTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B1
-
- GenericNestedTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B2
-
- GenericNestedTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericNestedTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B3
-
- GenericRecord - Interface in org.apache.avro.generic
-
A generic instance of a record schema.
- GenericRecordBuilder - Class in org.apache.avro.generic
-
A RecordBuilder for generic records.
- GenericRecordBuilder(Schema) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
-
Creates a GenericRecordBuilder for building Record instances.
- GenericRecordBuilder(GenericRecordBuilder) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
-
Creates a GenericRecordBuilder by copying an existing GenericRecordBuilder.
- GenericRecordBuilder(GenericData.Record) - Constructor for class org.apache.avro.generic.GenericRecordBuilder
-
Creates a GenericRecordBuilder by copying an existing record instance.
- GenericRequestor - Class in org.apache.avro.ipc.generic
-
Requestor
implementation for generic Java data.
- GenericRequestor(Protocol, Transceiver) - Constructor for class org.apache.avro.ipc.generic.GenericRequestor
-
- GenericRequestor(Protocol, Transceiver, GenericData) - Constructor for class org.apache.avro.ipc.generic.GenericRequestor
-
- GenericResponder - Class in org.apache.avro.ipc.generic
-
Responder
implementation for generic Java data.
- GenericResponder(Protocol) - Constructor for class org.apache.avro.ipc.generic.GenericResponder
-
- GenericResponder(Protocol, GenericData) - Constructor for class org.apache.avro.ipc.generic.GenericResponder
-
- GenericStringTest - Class in org.apache.avro.perf.test.generic
-
- GenericStringTest() - Constructor for class org.apache.avro.perf.test.generic.GenericStringTest
-
- GenericStringTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
-
- GenericStringTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
-
- GenericStringTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_decode_jmhTest
-
- GenericStringTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_encode_jmhTest
-
- GenericStringTest_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType
-
- GenericStringTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B1
-
- GenericStringTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B2
-
- GenericStringTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B3
-
- GenericStringTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType
-
- GenericStringTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B1
-
- GenericStringTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B2
-
- GenericStringTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B3
-
- GenericStringTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType
-
- GenericStringTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B1
-
- GenericStringTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B2
-
- GenericStringTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericStringTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B3
-
- GenericTest - Class in org.apache.avro.perf.test.generic
-
- GenericTest() - Constructor for class org.apache.avro.perf.test.generic.GenericTest
-
- GenericTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
-
- GenericTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
-
- GenericTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_decode_jmhTest
-
- GenericTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_encode_jmhTest
-
- GenericTest_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType
-
- GenericTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B1
-
- GenericTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B2
-
- GenericTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B3
-
- GenericTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType
-
- GenericTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B1
-
- GenericTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B2
-
- GenericTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B3
-
- GenericTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType
-
- GenericTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B1
-
- GenericTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B2
-
- GenericTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B3
-
- GenericWithDefaultTest - Class in org.apache.avro.perf.test.generic
-
- GenericWithDefaultTest() - Constructor for class org.apache.avro.perf.test.generic.GenericWithDefaultTest
-
- GenericWithDefaultTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
-
- GenericWithDefaultTest.TestStateEncode - Class in org.apache.avro.perf.test.generic
-
- GenericWithDefaultTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_decode_jmhTest
-
- GenericWithDefaultTest_encode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_encode_jmhTest
-
- GenericWithDefaultTest_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType
-
- GenericWithDefaultTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B1
-
- GenericWithDefaultTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B2
-
- GenericWithDefaultTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B3
-
- GenericWithDefaultTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType
-
- GenericWithDefaultTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B1
-
- GenericWithDefaultTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
-
- GenericWithDefaultTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B3
-
- GenericWithDefaultTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType
-
- GenericWithDefaultTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B1
-
- GenericWithDefaultTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
-
- GenericWithDefaultTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithDefaultTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B3
-
- GenericWithOutOfOrderTest - Class in org.apache.avro.perf.test.generic
-
- GenericWithOutOfOrderTest() - Constructor for class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest
-
- GenericWithOutOfOrderTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
-
- GenericWithOutOfOrderTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- GenericWithOutOfOrderTest_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType
-
- GenericWithOutOfOrderTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B1
-
- GenericWithOutOfOrderTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B2
-
- GenericWithOutOfOrderTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B3
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B1
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithOutOfOrderTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B3
-
- GenericWithPromotionTest - Class in org.apache.avro.perf.test.generic
-
- GenericWithPromotionTest() - Constructor for class org.apache.avro.perf.test.generic.GenericWithPromotionTest
-
- GenericWithPromotionTest.TestStateDecode - Class in org.apache.avro.perf.test.generic
-
- GenericWithPromotionTest_decode_jmhTest - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_decode_jmhTest
-
- GenericWithPromotionTest_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType
-
- GenericWithPromotionTest_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B1
-
- GenericWithPromotionTest_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B2
-
- GenericWithPromotionTest_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B3
-
- GenericWithPromotionTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType
-
- GenericWithPromotionTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B1
-
- GenericWithPromotionTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
-
- GenericWithPromotionTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.generic.generated
-
- GenericWithPromotionTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B3
-
- 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(int) - Method in class org.apache.avro.generic.GenericData.Array
-
- get() - Static method in class org.apache.avro.generic.GenericData
-
Return the singleton instance.
- get(String) - Method in class org.apache.avro.generic.GenericData.Record
-
- get(int) - Method in class org.apache.avro.generic.GenericData.Record
-
- get(String) - Method in interface org.apache.avro.generic.GenericRecord
-
Return the value of a field given its name.
- get(String) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Gets the value of a field.
- get(Schema.Field) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Gets the value of a field.
- get(int) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Gets the value of a field.
- get(int) - Method in interface org.apache.avro.generic.IndexedRecord
-
Return the value of a field given its position in the schema.
- get(K) - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
-
Gets the first value associated with a given key, or null if it is not found.
- get() - Method in class org.apache.avro.hadoop.io.AvroKeyValue
-
Gets the wrapped key/value GenericRecord.
- get() - Static method in class org.apache.avro.io.DecoderFactory
-
Returns an immutable static DecoderFactory configured with default settings
All mutating methods throw IllegalArgumentExceptions.
- get() - Static method in class org.apache.avro.io.EncoderFactory
-
Returns an immutable static DecoderFactory with default configuration.
- get() - Static method in class org.apache.avro.io.FastReaderBuilder
-
- get(int) - Method in class org.apache.avro.io.parsing.Symbol.Sequence
-
- get() - Method in class org.apache.avro.ipc.CallFuture
-
- get(long, TimeUnit) - Method in class org.apache.avro.ipc.CallFuture
-
- get(int) - Method in class org.apache.avro.ipc.HandshakeRequest
-
- get(int) - Method in class org.apache.avro.ipc.HandshakeResponse
-
- get(int) - Method in class org.apache.avro.mapred.Pair
-
- get() - Static method in class org.apache.avro.protobuf.ProtobufData
-
Return the singleton instance.
- get() - Static method in class org.apache.avro.reflect.ReflectData.AllowNull
-
Return the singleton instance.
- get() - Static method in class org.apache.avro.reflect.ReflectData
-
Return the singleton instance.
- get() - Static method in class org.apache.avro.specific.SpecificData
-
Return the singleton instance.
- get(int) - Method in exception org.apache.avro.specific.SpecificExceptionBase
-
- get(int) - Method in class org.apache.avro.specific.SpecificRecordBase
-
- get(String) - Method in class org.apache.avro.specific.SpecificRecordBase
-
- get() - Static method in class org.apache.avro.thrift.ThriftData
-
Return the singleton instance.
- get(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
-
- getAliases() - Method in class org.apache.avro.Schema
-
If this is a record, enum or fixed, return its aliases, if any.
- 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
-
- getArraySize(Object) - Method in class org.apache.avro.generic.GenericDatumWriter
-
- getArraySize() - Method in class org.apache.avro.perf.test.BasicArrayState
-
- 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(String) - Method in class org.apache.trevni.MetaData
-
Return true iff a key has any value, false if it is not present.
- getBufferList() - Method in class org.apache.avro.util.ByteBufferOutputStream
-
Returns all data written and resets the stream to be empty.
- getBufferSize() - Method in class org.apache.avro.io.EncoderFactory
-
Returns this factory's configured default buffer size.
- getBufferSizeBytes() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Gets the desired size of the buffer used when flushing records to disk.
- getByteLength() - Method in class org.apache.avro.util.Utf8
-
Return length in bytes.
- getBytes() - Method in class org.apache.avro.util.Utf8
-
Return UTF-8 encoded bytes.
- getBytesFor(String) - Static method in class org.apache.avro.util.Utf8
-
Gets the UTF-8 bytes for a String
- getCause() - Method in interface org.apache.avro.data.ErrorBuilder
-
Gets the error cause
- getCause() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
-
- getCharts() - Method in class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
-
- getChecksum() - Method in class org.apache.trevni.MetaData
-
Return the checksum algorithm name.
- getChildren() - Method in class org.apache.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>, Transceiver) - Static method in class org.apache.avro.ipc.reflect.ReflectRequestor
-
Create a proxy instance whose methods invoke RPCs.
- getClient(Class<T>, Transceiver, ReflectData) - Static method in class org.apache.avro.ipc.reflect.ReflectRequestor
-
Create a proxy instance whose methods invoke RPCs.
- getClient(Class<T>, ReflectRequestor) - Static method in class org.apache.avro.ipc.reflect.ReflectRequestor
-
Create a proxy instance whose methods invoke RPCs.
- getClient(Class<T>, Transceiver) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Create a proxy instance whose methods invoke RPCs.
- getClient(Class<T>, Transceiver, SpecificData) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Create a proxy instance whose methods invoke RPCs.
- getClient(Class<T>, SpecificRequestor) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Create a proxy instance whose methods invoke RPCs.
- getClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'clientHash' field.
- getClientHash() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'clientHash' field.
- getClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'clientProtocol' field.
- getClientProtocol() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'clientProtocol' field.
- getCodec() - Method in class org.apache.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, Reporter) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
-
- getCollector(String, String, Reporter) - Method in class org.apache.avro.mapred.AvroMultipleOutputs
-
Gets the output collector for a named output.
- 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.DecimalConversion
-
- 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.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.protobuf.ProtoConversions.TimestampMicrosConversion
-
- getConvertedType() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
-
- getCountersEnabled(JobConf) - Static method in class org.apache.avro.mapred.AvroMultipleOutputs
-
Returns if the counters for the named outputs are enabled or not.
- getCountersEnabled(JobContext) - Static method in class org.apache.avro.mapreduce.AvroMultipleOutputs
-
Returns if the counters for the named outputs are enabled or not.
- getCurrentKey() - Method in class org.apache.avro.mapreduce.AvroKeyRecordReader
- getCurrentKey() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordReader
- getCurrentKey() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
- getCurrentKey() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordReader
- getCurrentKey() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordReader
- getCurrentRecord() - Method in class org.apache.avro.mapreduce.AvroRecordReaderBase
-
Gets the current record read from the Avro container file.
- getCurrentRecord() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordReaderBase
-
Gets the current record read from the Trevni container file.
- getCurrentValue() - Method in class org.apache.avro.mapreduce.AvroKeyRecordReader
- getCurrentValue() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordReader
- getCurrentValue() - Method in class org.apache.avro.mapreduce.AvroSequenceFileInputFormat.AvroSequenceFileRecordReader
- getCurrentValue() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyRecordReader
- getCurrentValue() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueRecordReader
- getData() - Method in class org.apache.avro.generic.GenericDatumReader
-
- getData() - Method in class org.apache.avro.generic.GenericDatumWriter
-
- 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, Schema) - Method in class org.apache.avro.ipc.generic.GenericResponder
-
- getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.reflect.ReflectRequestor
-
- getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.reflect.ReflectResponder
-
- getDatumReader(Schema) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Deprecated.
- getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
-
- getDatumReader(Schema, Schema) - Method in class org.apache.avro.ipc.specific.SpecificResponder
-
- getDatumWriter(Schema) - Method in class org.apache.avro.ipc.generic.GenericResponder
-
- getDatumWriter(Schema) - Method in class org.apache.avro.ipc.reflect.ReflectRequestor
-
- getDatumWriter(Schema) - Method in class org.apache.avro.ipc.reflect.ReflectResponder
-
- getDatumWriter(Schema) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
-
- getDatumWriter(Schema) - Method in class org.apache.avro.ipc.specific.SpecificResponder
-
- 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.
- getDefaultValue(Schema.Field) - Method in class org.apache.avro.generic.GenericData
-
Gets the default value of the given field, if any.
- getDescription() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets a human readable description of this validation result.
- getDeserializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.hadoop.io.AvroSerialization
-
Gets an object capable of deserializing the output from a Mapper.
- getDeserializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.mapred.AvroSerialization
-
Returns the specified map output deserializer.
- getDoc() - Method in class org.apache.avro.Protocol
-
Doc string for this protocol.
- getDoc() - Method in class org.apache.avro.Protocol.Message
-
- getDoc() - Method in class org.apache.avro.Schema
-
If this is a record, enum, or fixed, returns its docstring, if available.
- getElementType() - Method in class org.apache.avro.Schema
-
If this is an array, returns its element type.
- 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.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
-
- getField(Object, String, int, Object) - Method in class org.apache.avro.generic.GenericData
-
- getField(Object, String, int) - Method in class org.apache.avro.protobuf.ProtobufData
-
- getField(Object, String, int, Object) - Method in class org.apache.avro.protobuf.ProtobufData
-
- getField(Object, String, int) - Method in class org.apache.avro.reflect.ReflectData
-
- getField(Object, String, int, Object) - Method in class org.apache.avro.reflect.ReflectData
-
- getField(String) - Method in class org.apache.avro.Schema
-
If this is a record, returns the Field with the given name
fieldName.
- getField(Object, String, int) - Method in class org.apache.avro.thrift.ThriftData
-
- getField(Object, String, int, Object) - Method in class org.apache.avro.thrift.ThriftData
-
- 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.
- 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 field
MODEL$
, in order to
get the correct
Conversion
instances for the class.
- getForSchema(Schema) - Static method in class org.apache.avro.specific.SpecificData
-
For RECORD 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
-
- getHandshakeRequest() - Method in class org.apache.avro.ipc.RPCContext
-
Get the handshake request of this RPC.
- getHandshakeResponse() - Method in class org.apache.avro.ipc.RPCContext
-
Get the handshake response of this RPC.
- getHeader() - Method in class org.apache.avro.file.DataFileStream
-
A handle that can be used to reopen this stream without rereading the head.
- getIncludes() - Method in class org.apache.avro.mojo.AbstractAvroMojo
-
- getIncludes() - Method in class org.apache.avro.mojo.IDLProtocolMojo
-
- getIncludes() - Method in class org.apache.avro.mojo.ProtocolMojo
-
- getIncludes() - Method in class org.apache.avro.mojo.SchemaMojo
-
- 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.
- 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.reflect.MapEntry
-
- 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
-
- 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.DecimalConversion
-
- 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.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.protobuf.ProtoConversions.TimestampMicrosConversion
-
- getLogicalTypeName() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
-
- getLong(String) - Method in class org.apache.trevni.MetaData
-
Return the value of a metadata property as a long.
- getMapEntries(Object) - Method in class org.apache.avro.generic.GenericDatumWriter
-
- 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
-
- 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
-
- 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(String) - Method in class org.apache.avro.file.DataFileReader12
-
Return the value of a metadata property.
- getMeta(String) - Method in class org.apache.avro.file.DataFileStream
-
Return the value of a metadata property.
- getMeta() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'meta' field.
- getMeta() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'meta' field.
- getMeta() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'meta' field.
- getMeta() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'meta' field.
- getMetadata() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Gets the SequenceFile metadata to store in the header.
- getMetaData() - Method in class org.apache.trevni.ColumnFileReader
-
Return this file's metadata.
- getMetaData() - Method in class org.apache.trevni.ColumnFileWriter
-
Return this file's metadata.
- getMetaKeys() - Method in class org.apache.avro.file.DataFileStream
-
Return the list of keys in the metadata
- getMetaLong(String) - Method in class org.apache.avro.file.DataFileReader12
-
Return the value of a metadata property.
- getMetaLong(String) - Method in class org.apache.avro.file.DataFileStream
-
Return the value of a metadata property.
- getMetaString(String) - Method in class org.apache.avro.file.DataFileReader12
-
Return the value of a metadata property.
- getMetaString(String) - Method in class org.apache.avro.file.DataFileStream
-
Return the value of a metadata property.
- 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.ipc.stats.StatsServlet.RenderableMessage
-
- 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.
- getNamespace(Descriptors.FileDescriptor, Descriptors.Descriptor) - Method in class org.apache.avro.protobuf.ProtobufData
-
- 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.
- 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
-
- 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.
- 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>.
- getOptionalMeta() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'meta' field as an Optional<java.util.Map>.
- getOptionalMeta() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'meta' field as an Optional<java.util.Map>.
- getOptionalMeta() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'meta' field as an Optional<java.util.Map>.
- 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, Field) - Method in class org.apache.avro.reflect.ReflectData
-
Get or create new value instance for a field
- getOrCreateDefaultValue(Type) - Method in class org.apache.avro.reflect.ReflectData
-
Get or create new value instance for a type.
- 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.
- 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
-
- 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(Class) - Static method in class org.apache.avro.grpc.AvroGrpcUtils
-
Gets the
Protocol
from the Avro 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
- 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.
- 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.DecimalConversion
-
- 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.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.protobuf.ProtoConversions.TimestampMicrosConversion
-
- getRecommendedSchema() - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.AvroAsTextInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.AvroInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.AvroUtf8InputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.avro.mapred.SequenceFileInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.trevni.avro.AvroTrevniInputFormat
-
- getRecordSchema(Object) - Method in class org.apache.avro.generic.GenericData
-
Called to obtain the schema of a record.
- getRecordSchema(Object) - Method in class org.apache.avro.protobuf.ProtobufData
-
- getRecordSchema(Object) - Method in class org.apache.avro.reflect.ReflectData
-
- getRecordSchema(Object) - Method in class org.apache.avro.thrift.ThriftData
-
- getRecordState(Object, Schema) - Method in class org.apache.avro.generic.GenericData
-
- getRecordState(Object, Schema) - Method in class org.apache.avro.protobuf.ProtobufData
-
- getRecordState(Object, Schema) - Method in class org.apache.avro.reflect.ReflectData
-
- getRecordState(Object, Schema) - Method in class org.apache.avro.thrift.ThriftData
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.avro.mapred.AvroOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.avro.mapred.AvroTextOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyOutputFormat
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroKeyValueOutputFormat
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.avro.mapreduce.AvroSequenceFileOutputFormat
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.trevni.avro.AvroTrevniOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueOutputFormat
- getReflectData() - Method in class org.apache.avro.ipc.reflect.ReflectRequestor
-
- getReflectData() - Method in class org.apache.avro.ipc.reflect.ReflectResponder
-
- getRemote() - Method in class org.apache.avro.ipc.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(Object) - Static method in class org.apache.avro.ipc.specific.SpecificRequestor
-
Return the remote protocol for a proxy.
- getRemote() - Method in class org.apache.avro.ipc.Transceiver
-
- 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.
- 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.
- 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.Array
-
- getSchema() - Method in class org.apache.avro.generic.GenericData.EnumSymbol
-
- getSchema() - Method in class org.apache.avro.generic.GenericData.Fixed
-
- getSchema() - Method in class org.apache.avro.generic.GenericData.Record
-
- getSchema() - Method in class org.apache.avro.generic.GenericDatumReader
-
Return the writer's schema.
- getSchema(Schema, Schema) - Static method in class org.apache.avro.hadoop.io.AvroKeyValue
-
Creates a KeyValuePair generic record schema.
- getSchema() - Method in 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(Class) - Method in class org.apache.avro.protobuf.ProtobufData
-
Return a record schema given a protobuf message class.
- getSchema(Descriptors.Descriptor) - Method in class org.apache.avro.protobuf.ProtobufData
-
- getSchema(Descriptors.FieldDescriptor) - Method in class org.apache.avro.protobuf.ProtobufData
-
- getSchema(Descriptors.EnumDescriptor) - Method in class org.apache.avro.protobuf.ProtobufData
-
- getSchema() - Method in class org.apache.avro.reflect.CustomEncoding
-
- getSchema(Type) - Method in class org.apache.avro.specific.SpecificData
-
Find the schema for a Java type.
- getSchema() - Method in exception org.apache.avro.specific.SpecificExceptionBase
-
- getSchema() - Method in class org.apache.avro.specific.SpecificFixed
-
- getSchema() - Method in class org.apache.avro.specific.SpecificRecordBase
-
- getSchema(Class) - Method in class org.apache.avro.thrift.ThriftData
-
Return a record schema given a thrift generated class.
- getSchemaName(Object) - Method in class org.apache.avro.generic.GenericData
-
Return the schema full name for a datum.
- getSchemaName(Object) - Method in class org.apache.avro.specific.SpecificData
-
- getSchemaName(Object) - Method in class org.apache.avro.thrift.ThriftData
-
- getSerial() - Method in class org.apache.avro.ipc.netty.NettyTransportCodec.NettyDataPack
-
- getSerializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.hadoop.io.AvroSerialization
-
Gets an object capable of serializing output from a Mapper.
- getSerializer(Class<AvroWrapper<T>>) - Method in class org.apache.avro.mapred.AvroSerialization
-
Returns the specified output serializer.
- getServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Gets the value of the 'serverHash' field.
- getServerHash() - Method in class org.apache.avro.ipc.HandshakeRequest
-
Gets the value of the 'serverHash' field.
- getServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'serverHash' field.
- getServerHash() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'serverHash' field.
- getServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Gets the value of the 'serverProtocol' field.
- getServerProtocol() - Method in class org.apache.avro.ipc.HandshakeResponse
-
Gets the value of the 'serverProtocol' field.
- 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
-
- 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
-
- getSpecificData() - Method in class org.apache.avro.specific.SpecificDatumWriter
-
Returns the
SpecificData
implementation used by this writer.
- 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...
- getTestIncludes() - Method in class org.apache.avro.mojo.AbstractAvroMojo
-
- getTestIncludes() - Method in class org.apache.avro.mojo.IDLProtocolMojo
-
- getTestIncludes() - Method in class org.apache.avro.mojo.ProtocolMojo
-
- getTestIncludes() - Method in class org.apache.avro.mojo.SchemaMojo
-
- 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.
- getType(String) - Method in class org.apache.avro.Protocol
-
Returns the named type.
- getType() - Method in class org.apache.avro.Schema
-
Return the type of this schema.
- getType() - Method in class org.apache.avro.SchemaCompatibility.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.
- 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 org.apache.avro.UnresolvedUnionException
-
- getUnresolvedDatum() - Method in exception org.apache.avro.UnresolvedUnionException
-
- getUsedConversionClasses(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
- getValidate() - Method in class org.apache.avro.Schema.Parser
-
True iff names are validated.
- getValidateDefaults() - Method in class org.apache.avro.Schema.Parser
-
True iff default values are validated.
- getValue() - Method in exception 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
-
- getValue() - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
-
- getValueClass() - Method in class org.apache.avro.hadoop.io.AvroSequenceFile.Writer.Options
-
Gets the class of the value records.
- getValueReaderSchema(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
-
Gets the reader schema of the AvroValue datum that is being
serialized/deserialized.
- getValues(String) - Method in class org.apache.trevni.ColumnFileReader
-
Return an iterator over values in the named column.
- getValues(int) - Method in class org.apache.trevni.ColumnFileReader
-
Return an iterator over values in a column.
- getValueSchema() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader.Options
-
Gets the reader schema for the value.
- getValueSchema() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Writer.Options
-
Gets the value schema.
- getValueSchema(Schema) - Static method in class org.apache.avro.mapred.Pair
-
Return a pair's value schema.
- getValueType() - Method in class org.apache.avro.Schema
-
If this is a map, returns its value type.
- getValueWriterSchema(Configuration) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
-
Gets the writer schema of the AvroValue datum that is being
serialized/deserialized.
- getWriter() - Method in class org.apache.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets the writer schema that was validated.
- 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
-
- 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
-
- IdlTool - Class in org.apache.avro.tool
-
Tool implementation for generating Avro JSON schemata from idl format files.
- IdlTool() - Constructor for class org.apache.avro.tool.IdlTool
-
- IdlToSchemataTool - Class in org.apache.avro.tool
-
Extract the Avro JSON schemata of the types of a protocol defined through an
idl format file.
- IdlToSchemataTool() - Constructor for class org.apache.avro.tool.IdlToSchemataTool
-
- IGNORE_FILES_WITHOUT_EXTENSION_KEY - Static variable in class org.apache.avro.mapred.AvroInputFormat
-
Whether to silently ignore input files without the .avro extension
- IGNORE_INPUTS_WITHOUT_EXTENSION_DEFAULT - Static variable in class org.apache.avro.mapred.AvroInputFormat
-
Default of whether to silently ignore input files without the .avro
extension.
- 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.
- 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.
- 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
-
- 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
- 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
-
Transmit inputs to a map or reduce task sub-process.
- 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
-
- 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
-
- 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
-
- 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.io.parsing.Symbol
-
- intBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
Build an int type that can set custom properties.
- intBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
Build an int type that can set custom properties.
- intBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
Build an int type that can set custom properties.
- intCheckAction(int) - Static method in class org.apache.avro.io.parsing.Symbol
-
- 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
- IntTest - Class in org.apache.avro.perf.test.basic
-
- IntTest() - Constructor for class org.apache.avro.perf.test.basic.IntTest
-
- IntTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
-
- IntTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
-
- IntTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_decode_jmhTest
-
- IntTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_encode_jmhTest
-
- IntTest_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_jmhType
-
- IntTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B1
-
- IntTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B2
-
- IntTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B3
-
- IntTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType
-
- IntTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B1
-
- IntTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B2
-
- IntTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B3
-
- IntTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType
-
- IntTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B1
-
- IntTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B2
-
- IntTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- IntTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B3
-
- 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 in org.apache.avro
-
- InvalidAvroMagicException(String) - Constructor for exception org.apache.avro.InvalidAvroMagicException
-
- InvalidNumberEncodingException - Exception in org.apache.avro
-
- InvalidNumberEncodingException(String) - Constructor for exception 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(Object) - Method in class org.apache.avro.generic.GenericData
-
- isArray(Object) - Method in class org.apache.avro.protobuf.ProtobufData
-
- isArray(Object) - Method in class org.apache.avro.reflect.ReflectData
-
Returns true for arrays and false otherwise, with the following exceptions:
- isArray() - Method in class org.apache.trevni.ColumnMetaData
-
Return true if this column is an array.
- isArray(boolean) - Method in class org.apache.trevni.ColumnMetaData
-
Set whether this column is an array.
- isBoolean(Object) - Method in class org.apache.avro.generic.GenericData
-
- isBytes(Object) - Method in class org.apache.avro.generic.GenericData
-
- isBytes(Object) - Method in class org.apache.avro.protobuf.ProtobufData
-
- isBytes(Object) - Method in class org.apache.avro.reflect.ReflectData
-
- isBytes(Object) - Method in class org.apache.avro.thrift.ThriftData
-
- isCancelled() - Method in class org.apache.avro.ipc.CallFuture
-
- 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
-
- 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.
- isDone() - Method in class org.apache.avro.ipc.CallFuture
-
- isDouble(Object) - Method in class org.apache.avro.generic.GenericData
-
- isEmpty - Variable in class org.apache.avro.io.JsonEncoder
-
Has anything been written into the collections?
- isEmpty() - Method in class org.apache.avro.util.WeakIdentityHashMap
-
- isEnd() - Method in class org.apache.avro.io.BinaryDecoder
-
Returns true if the current BinaryDecoder is at the end of its source data
and cannot read any further without throwing an EOFException or other
IOException.
- isEnum(Object) - Method in class org.apache.avro.generic.GenericData
-
- isEnum(Object) - Method in class org.apache.avro.specific.SpecificData
-
- isEnum(Object) - Method in class org.apache.avro.thrift.ThriftData
-
- isError() - Method in class org.apache.avro.ipc.RPCContext
-
Indicates whether an exception was generated at the server
- isError() - Method in class org.apache.avro.Schema
-
Returns true if this record is an error type.
- isFastReaderEnabled() - Method in class org.apache.avro.generic.GenericData
-
- isFixed(Object) - Method in class org.apache.avro.generic.GenericData
-
- isFloat(Object) - Method in class org.apache.avro.generic.GenericData
-
- isFlushOnEveryBlock() - Method in class org.apache.avro.file.DataFileWriter
-
- 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
-
- isKeyClassEnabled() - Method in class org.apache.avro.io.FastReaderBuilder
-
- isLong(Object) - Method in class org.apache.avro.generic.GenericData
-
- isMap(Object) - Method in class org.apache.avro.generic.GenericData
-
- 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 an union type containing null.
- 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
-
- isRecord(Object) - Method in class org.apache.avro.protobuf.ProtobufData
-
- isRecord(Object) - Method in class org.apache.avro.reflect.ReflectData
-
- isRecord(Object) - Method in class org.apache.avro.thrift.ThriftData
-
- isReserved(String) - Static method in class org.apache.trevni.MetaData
-
Test if a metadata key is reserved.
- isReservedMeta(String) - Static method in class org.apache.avro.file.DataFileWriter
-
- isSplitable(FileSystem, Path) - Method in class org.apache.avro.mapred.AvroUtf8InputFormat
-
- isSplitable(FileSystem, Path) - Method in class org.apache.trevni.avro.AvroTrevniInputFormat
-
- isString(Object) - Method in class org.apache.avro.generic.GenericData
-
- isStringable(Schema) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for template use.
- 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().
- 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
-
- 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 an union type.
- 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.
- isValidValue(Schema.Field, Object) - Static method in class org.apache.avro.data.RecordBuilderBase
-
Tests whether a value is valid for a specified field.
- ITEM_END - Static variable in class org.apache.avro.io.parsing.Symbol
-
- items() - Method in class org.apache.avro.SchemaBuilder.ArrayBuilder
-
Return a type builder for configuring the array's nested items schema.
- items(Schema) - Method in class org.apache.avro.SchemaBuilder.ArrayBuilder
-
Complete configuration of this array, setting the schema of the array items
to the schema provided.
- iterator() - Method in class org.apache.avro.file.DataFileReader12
-
- iterator() - Method in class org.apache.avro.file.DataFileStream
-
Returns an iterator over entries in this file.
- iterator() - Method in class org.apache.avro.generic.GenericData.Array
-
- iterator() - Method in class org.apache.avro.hadoop.file.SortedKeyValueFile.Reader
-
Returns an iterator starting at the current position in the file.
- Iterator(Iterator<? extends GenericRecord>) - Constructor for class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
-
Constructs an iterator over key-value map entries out of a generic iterator.
- iterator() - Method in class org.apache.avro.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
-
- 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.
- NamedBuilder(SchemaBuilder.NameContext, String) - Constructor for class org.apache.avro.SchemaBuilder.NamedBuilder
-
- names - Variable in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
- namespace(String) - Method in class org.apache.avro.SchemaBuilder.NamespacedBuilder
-
Set the namespace of this type.
- NamespacedBuilder(SchemaBuilder.Completion<R>, SchemaBuilder.NameContext, String) - Constructor for class org.apache.avro.SchemaBuilder.NamespacedBuilder
-
- 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
-
- 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, 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>) - 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.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.
- 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(HandshakeRequest.Builder) - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Creates a new HandshakeRequest RecordBuilder by copying an existing Builder.
- newBuilder(HandshakeRequest) - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Creates a new HandshakeRequest RecordBuilder by copying an existing HandshakeRequest instance.
- newBuilder() - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Creates a new HandshakeResponse RecordBuilder.
- newBuilder(HandshakeResponse.Builder) - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Creates a new HandshakeResponse RecordBuilder by copying an existing Builder.
- newBuilder(HandshakeResponse) - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Creates a new HandshakeResponse RecordBuilder by copying an existing HandshakeResponse instance.
- 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(Object, Schema) - Method in interface org.apache.avro.generic.GenericData.InstanceSupplier
-
- newInstance(Class, Schema) - Static method in class org.apache.avro.specific.SpecificData
-
Create an instance of a class.
- newInstanceFromString(Class, String) - Method in class org.apache.avro.generic.GenericDatumReader
-
- newMap(Object, int) - Method in class org.apache.avro.generic.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
-
- 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(D) - Method in class org.apache.avro.file.DataFileReader12
-
Return the next datum in the file.
- next() - Method in class org.apache.avro.file.DataFileStream
-
Read the next datum in the file.
- next(D) - Method in class org.apache.avro.file.DataFileStream
-
Read the next datum from the file.
- next(D) - Method in interface org.apache.avro.file.FileReader
-
Read the next datum from the file.
- next() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
- next(AvroWrapper<T>, NullWritable) - Method in class org.apache.avro.mapred.AvroRecordReader
-
- next() - Method in class org.apache.avro.mapred.SequenceFileReader
-
- next(Pair<K, V>) - Method in class org.apache.avro.mapred.SequenceFileReader
-
- next() - Method in class org.apache.trevni.avro.AvroColumnReader
-
- next() - Method in class org.apache.trevni.ColumnValues
-
- nextBlock() - Method in class org.apache.avro.file.DataFileStream
-
Expert: Return the next block in the file, as binary-encoded data.
- 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.
- 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.
- 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
indices i
.
- 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.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 - Annotation Type in org.apache.avro.reflect
-
Declares that null is a valid value for a Java type.
- nullable() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
A shortcut for building a union of a type and null.
- nullable() - Method in class org.apache.avro.SchemaBuilder.FieldTypeBuilder
-
A shortcut for building a union of a type and null, with an optional default
value of the non-null type.
- nullable() - Static method in class org.apache.avro.SchemaBuilder
-
Create a builder for a union of a type and null.
- nullable() - Method in class org.apache.avro.SchemaBuilder.TypeBuilder
-
- nullableBoolean(String, boolean) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
-
Shortcut for creating a nullable boolean field: a union of boolean and null
with an boolean default.
- nullableBytes(String, byte[]) - Method in class org.apache.avro.SchemaBuilder.FieldAssembler
-
Shortcut for creating a nullable bytes field: a union of bytes and null with
a bytes default.
- 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.
- 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
-
- RandomData - Class in org.apache.avro.util
-
Generates schema data as Java objects with random values.
- RandomData(Schema, int) - Constructor for class org.apache.avro.util.RandomData
-
- RandomData(Schema, int, long) - Constructor for class org.apache.avro.util.RandomData
-
- RandomData(Schema, int, boolean) - 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
-
- RawMessageDecoder(GenericData, Schema) - Constructor for class org.apache.avro.message.RawMessageDecoder
-
- RawMessageDecoder(GenericData, Schema, Schema) - Constructor for class org.apache.avro.message.RawMessageDecoder
-
- 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
-
- RawMessageEncoder(GenericData, Schema, boolean) - Constructor for class org.apache.avro.message.RawMessageEncoder
-
- read(Object, Decoder) - Method in class org.apache.avro.data.Json.ObjectReader
-
- read(byte[], int, int) - Method in interface org.apache.avro.file.SeekableInput
-
- read(D, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
- read(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read data.
- read(byte[], int, int) - Method in class org.apache.avro.grpc.AvroInputStream
-
- read() - Method in class org.apache.avro.grpc.AvroInputStream
-
- read(D, Decoder) - Method in interface org.apache.avro.io.DatumReader
-
Read a datum.
- 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(byte[], int, int) - Method in class org.apache.avro.mapred.FsInput
-
- read(Object, Decoder) - Method in class org.apache.avro.reflect.CustomEncoding
-
- read(Object, Decoder) - Method in class org.apache.avro.reflect.DateAsLongEncoding
-
- read() - Method in class org.apache.avro.util.ByteBufferInputStream
-
- read(byte[], int, int) - Method in class org.apache.avro.util.ByteBufferInputStream
-
- read() - Method in class org.apache.avro.util.ReusableByteBufferInputStream
-
- 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
-
- 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
-
- 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
-
- readBytes(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read byte arrays.
- readBytes(Object, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read byte arrays.
- readBytes(ByteBuffer) - Method in class org.apache.avro.io.BinaryDecoder
-
- readBytes(ByteBuffer) - Method in class org.apache.avro.io.Decoder
-
- 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
-
- readBytes(Object, Decoder) - Method in class org.apache.avro.protobuf.ProtobufDatumReader
-
- readBytes(Object, Schema, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
-
- readDouble() - Method in class org.apache.avro.io.BinaryDecoder
-
- readDouble() - Method in class org.apache.avro.io.Decoder
-
- readDouble() - Method in class org.apache.avro.io.JsonDecoder
-
- readDouble() - Method in class org.apache.avro.io.ResolvingDecoder
-
- readDouble() - Method in class org.apache.avro.io.ValidatingDecoder
-
- readEnum(Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read an enum value.
- readEnum() - Method in class org.apache.avro.io.BinaryDecoder
-
- readEnum() - Method in class org.apache.avro.io.Decoder
-
Reads an enumeration.
- readEnum() - Method in class org.apache.avro.io.JsonDecoder
-
- readEnum() - Method in class org.apache.avro.io.ResolvingDecoder
-
- readEnum() - Method in class org.apache.avro.io.ValidatingDecoder
-
- Reader(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 - Variable in class org.apache.avro.io.parsing.Symbol.ResolvingAction
-
- reader - Variable in class org.apache.avro.Resolver.Action
-
- 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, Schema, Decoder) - Method in class org.apache.avro.ipc.generic.GenericRequestor
-
- readError(Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
-
Deprecated.
- readError(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
-
Reads an error message.
- readError(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
-
- 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 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
-
- 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(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read a fixed value.
- readFixed(byte[], int, int) - Method in class org.apache.avro.io.BinaryDecoder
-
- readFixed(byte[], int, int) - Method in class org.apache.avro.io.Decoder
-
Reads fixed sized binary object.
- readFixed(byte[]) - Method in class org.apache.avro.io.Decoder
-
A shorthand for readFixed(bytes, 0, bytes.length).
- readFixed(byte[], int, int) - Method in class org.apache.avro.io.JsonDecoder
-
- readFixed(byte[], int, int) - Method in class org.apache.avro.io.ValidatingDecoder
-
- readFloat() - Method in class org.apache.avro.io.BinaryDecoder
-
- readFloat() - Method in class org.apache.avro.io.Decoder
-
- 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
-
- readIndex() - Method in class org.apache.avro.io.JsonDecoder
-
- readIndex() - Method in class org.apache.avro.io.ResolvingDecoder
-
- readIndex() - Method in class org.apache.avro.io.ValidatingDecoder
-
- readInt(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read integers.
- readInt() - Method in class org.apache.avro.io.BinaryDecoder
-
- readInt() - Method in class org.apache.avro.io.Decoder
-
- readInt() - Method in class org.apache.avro.io.JsonDecoder
-
- readInt() - Method in class org.apache.avro.io.ValidatingDecoder
-
- readInt(Object, Schema, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
-
- readInt(Object, Schema, Decoder) - Method in class org.apache.avro.thrift.ThriftDatumReader
-
- readLong() - Method in class org.apache.avro.io.BinaryDecoder
-
- readLong() - Method in class org.apache.avro.io.Decoder
-
- readLong() - Method in class org.apache.avro.io.JsonDecoder
-
- readLong() - Method in class org.apache.avro.io.ResolvingDecoder
-
- readLong() - Method in class org.apache.avro.io.ValidatingDecoder
-
- readMap(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read a map instance.
- readMapKey(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
- readMapStart() - Method in class org.apache.avro.io.BinaryDecoder
-
- readMapStart() - Method in class org.apache.avro.io.Decoder
-
Reads and returns the size of the next block of map-entries.
- readMapStart() - Method in class org.apache.avro.io.JsonDecoder
-
- readMapStart() - Method in class org.apache.avro.io.ValidatingDecoder
-
- readNull() - Method in class org.apache.avro.io.BinaryDecoder
-
- readNull() - Method in class org.apache.avro.io.Decoder
-
"Reads" a null value.
- readNull() - Method in class org.apache.avro.io.JsonDecoder
-
- readNull() - Method in class org.apache.avro.io.ValidatingDecoder
-
- readRecord(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read a record instance.
- readRecord(Object, Schema, ResolvingDecoder) - Method in class org.apache.avro.protobuf.ProtobufDatumReader
-
- 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, Schema, Decoder) - Method in class org.apache.avro.ipc.generic.GenericRequestor
-
- readResponse(Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
-
Deprecated.
- readResponse(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.Requestor
-
Reads a response message.
- readResponse(Schema, Schema, Decoder) - Method in class org.apache.avro.ipc.specific.SpecificRequestor
-
- readString(Object, Schema, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read strings.
- readString(Object, Decoder) - Method in class org.apache.avro.generic.GenericDatumReader
-
Called to read strings.
- readString(Utf8) - Method in class org.apache.avro.io.BinaryDecoder
-
- readString() - Method in class org.apache.avro.io.BinaryDecoder
-
- readString(Utf8) - Method in class org.apache.avro.io.Decoder
-
- readString() - Method in class org.apache.avro.io.Decoder
-
- readString(Utf8) - Method in class org.apache.avro.io.JsonDecoder
-
- readString() - Method in class org.apache.avro.io.JsonDecoder
-
- readString(Utf8) - Method in class org.apache.avro.io.ResolvingDecoder
-
- readString() - Method in class org.apache.avro.io.ResolvingDecoder
-
- readString(Utf8) - Method in class org.apache.avro.io.ValidatingDecoder
-
- readString() - Method in class org.apache.avro.io.ValidatingDecoder
-
- readString(Object, Decoder) - Method in class org.apache.avro.reflect.ReflectDatumReader
-
- 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(Schema) - Constructor for class org.apache.avro.generic.GenericData.Record
-
- Record(GenericData.Record, boolean) - Constructor for class org.apache.avro.generic.GenericData.Record
-
- record(String) - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
Build an Avro record type.
- record(String) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
Build an Avro record type.
- record(String) - Static method in class org.apache.avro.SchemaBuilder
-
Create a builder for an Avro record with the specified name.
- record(String) - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
Build an Avro record type.
- RECORD_END - Static variable in class org.apache.avro.io.parsing.Symbol
-
- RECORD_START - Static variable in class org.apache.avro.io.parsing.Symbol
-
- RecordBuilder<T> - Interface in org.apache.avro.data
-
Interface for record builders
- RecordBuilderBase<T extends IndexedRecord> - Class in org.apache.avro.data
-
Abstract base class for RecordBuilder implementations.
- RecordBuilderBase(Schema, GenericData) - Constructor for class org.apache.avro.data.RecordBuilderBase
-
Creates a RecordBuilderBase for building records of the given type.
- RecordBuilderBase(RecordBuilderBase<T>, GenericData) - Constructor for class org.apache.avro.data.RecordBuilderBase
-
RecordBuilderBase copy constructor.
- RecordCountTool - Class in org.apache.avro.tool
-
Counts the records in avro files or folders
- RecordCountTool() - Constructor for class org.apache.avro.tool.RecordCountTool
-
- 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.TestStateDecode - Class in org.apache.avro.perf.test.record
-
- RecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_decode_jmhTest
-
- RecordTest_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_jmhType
-
- RecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B1
-
- RecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B2
-
- RecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B3
-
- RecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType
-
- RecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B1
-
- RecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B2
-
- RecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B3
-
- RecordWithDefaultTest - Class in org.apache.avro.perf.test.record
-
- RecordWithDefaultTest() - Constructor for class org.apache.avro.perf.test.record.RecordWithDefaultTest
-
- RecordWithDefaultTest.TestStateDecode - Class in org.apache.avro.perf.test.record
-
- RecordWithDefaultTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_decode_jmhTest
-
- RecordWithDefaultTest_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType
-
- RecordWithDefaultTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B1
-
- RecordWithDefaultTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B2
-
- RecordWithDefaultTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B3
-
- RecordWithDefaultTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType
-
- RecordWithDefaultTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B1
-
- RecordWithDefaultTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
-
- RecordWithDefaultTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithDefaultTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B3
-
- RecordWithOutOfOrderTest - Class in org.apache.avro.perf.test.record
-
- RecordWithOutOfOrderTest() - Constructor for class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest
-
- RecordWithOutOfOrderTest.TestStateDecode - Class in org.apache.avro.perf.test.record
-
- RecordWithOutOfOrderTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- RecordWithOutOfOrderTest_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType
-
- RecordWithOutOfOrderTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B1
-
- RecordWithOutOfOrderTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B2
-
- RecordWithOutOfOrderTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B3
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B1
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithOutOfOrderTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B3
-
- RecordWithPromotionTest - Class in org.apache.avro.perf.test.record
-
- RecordWithPromotionTest() - Constructor for class org.apache.avro.perf.test.record.RecordWithPromotionTest
-
- RecordWithPromotionTest.TestStateDecode - Class in org.apache.avro.perf.test.record
-
- RecordWithPromotionTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_decode_jmhTest
-
- RecordWithPromotionTest_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType
-
- RecordWithPromotionTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B1
-
- RecordWithPromotionTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B2
-
- RecordWithPromotionTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B3
-
- RecordWithPromotionTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType
-
- RecordWithPromotionTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B1
-
- RecordWithPromotionTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
-
- RecordWithPromotionTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- RecordWithPromotionTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B3
-
- RecordWriterFactory() - Constructor for class org.apache.avro.mapreduce.AvroKeyOutputFormat.RecordWriterFactory
-
- 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.
- ReflectBigRecordTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectBigRecordTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectBigRecordTest
-
- ReflectBigRecordTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectBigRecordTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectBigRecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_decode_jmhTest
-
- ReflectBigRecordTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_encode_jmhTest
-
- ReflectBigRecordTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType
-
- ReflectBigRecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B1
-
- ReflectBigRecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B2
-
- ReflectBigRecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B3
-
- ReflectBigRecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType
-
- ReflectBigRecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B1
-
- ReflectBigRecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
-
- ReflectBigRecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B3
-
- ReflectBigRecordTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType
-
- ReflectBigRecordTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B1
-
- ReflectBigRecordTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
-
- ReflectBigRecordTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectBigRecordTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B3
-
- 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
-
- ReflectDatumReader() - Constructor for class org.apache.avro.reflect.ReflectDatumReader
-
- ReflectDatumReader(Class<T>) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
-
Construct for reading instances of a class.
- ReflectDatumReader(Schema) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
-
Construct where the writer's and reader's schemas are the same.
- ReflectDatumReader(Schema, Schema) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
-
Construct given writer's and reader's schema.
- ReflectDatumReader(Schema, Schema, ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
-
Construct given writer's and reader's schema and the data model.
- ReflectDatumReader(ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumReader
-
- ReflectDatumWriter<T> - Class in org.apache.avro.reflect
-
- ReflectDatumWriter() - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
-
- ReflectDatumWriter(Class<T>) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
-
- ReflectDatumWriter(Class<T>, ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
-
- ReflectDatumWriter(Schema) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
-
- ReflectDatumWriter(Schema, ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
-
- ReflectDatumWriter(ReflectData) - Constructor for class org.apache.avro.reflect.ReflectDatumWriter
-
- ReflectDoubleArrayTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectDoubleArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest
-
- ReflectDoubleArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectDoubleArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectDoubleArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_decode_jmhTest
-
- ReflectDoubleArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_encode_jmhTest
-
- ReflectDoubleArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType
-
- ReflectDoubleArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B1
-
- ReflectDoubleArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B2
-
- ReflectDoubleArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B3
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B1
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B3
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B1
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectDoubleArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B3
-
- ReflectFloatArrayTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectFloatArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest
-
- ReflectFloatArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectFloatArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectFloatArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_decode_jmhTest
-
- ReflectFloatArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_encode_jmhTest
-
- ReflectFloatArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType
-
- ReflectFloatArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B1
-
- ReflectFloatArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B2
-
- ReflectFloatArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B3
-
- ReflectFloatArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType
-
- ReflectFloatArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B1
-
- ReflectFloatArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
-
- ReflectFloatArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B3
-
- ReflectFloatArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType
-
- ReflectFloatArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B1
-
- ReflectFloatArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
-
- ReflectFloatArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectFloatArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B3
-
- ReflectIntArrayTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectIntArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectIntArrayTest
-
- ReflectIntArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectIntArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectIntArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_decode_jmhTest
-
- ReflectIntArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_encode_jmhTest
-
- ReflectIntArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType
-
- ReflectIntArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B1
-
- ReflectIntArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B2
-
- ReflectIntArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B3
-
- ReflectIntArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType
-
- ReflectIntArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B1
-
- ReflectIntArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
-
- ReflectIntArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B3
-
- ReflectIntArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType
-
- ReflectIntArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B1
-
- ReflectIntArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
-
- ReflectIntArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectIntArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B3
-
- 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
-
- ReflectLargeFloatArrayBlockedTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest
-
- ReflectLargeFloatArrayBlockedTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectLargeFloatArrayBlockedTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectLargeFloatArrayBlockedTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- ReflectLargeFloatArrayBlockedTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_encode_jmhTest
-
- ReflectLargeFloatArrayBlockedTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType
-
- ReflectLargeFloatArrayBlockedTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B1
-
- ReflectLargeFloatArrayBlockedTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
-
- ReflectLargeFloatArrayBlockedTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B3
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B1
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B3
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B1
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B3
-
- ReflectLargeFloatArrayTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectLargeFloatArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest
-
- ReflectLargeFloatArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectLargeFloatArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectLargeFloatArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- ReflectLargeFloatArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_encode_jmhTest
-
- ReflectLargeFloatArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType
-
- ReflectLargeFloatArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B1
-
- ReflectLargeFloatArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B2
-
- ReflectLargeFloatArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B3
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B1
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B3
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B1
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B3
-
- ReflectLongArrayTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectLongArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectLongArrayTest
-
- ReflectLongArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectLongArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectLongArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_decode_jmhTest
-
- ReflectLongArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_encode_jmhTest
-
- ReflectLongArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType
-
- ReflectLongArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B1
-
- ReflectLongArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B2
-
- ReflectLongArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B3
-
- ReflectLongArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType
-
- ReflectLongArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B1
-
- ReflectLongArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
-
- ReflectLongArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B3
-
- ReflectLongArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType
-
- ReflectLongArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B1
-
- ReflectLongArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
-
- ReflectLongArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectLongArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B3
-
- ReflectNestedFloatArrayTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectNestedFloatArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest
-
- ReflectNestedFloatArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectNestedFloatArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectNestedFloatArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- ReflectNestedFloatArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_encode_jmhTest
-
- ReflectNestedFloatArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType
-
- ReflectNestedFloatArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B1
-
- ReflectNestedFloatArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B2
-
- ReflectNestedFloatArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B3
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B1
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B3
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B1
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B3
-
- ReflectNestedObjectArrayTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectNestedObjectArrayTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest
-
- ReflectNestedObjectArrayTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectNestedObjectArrayTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectNestedObjectArrayTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- ReflectNestedObjectArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_encode_jmhTest
-
- ReflectNestedObjectArrayTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType
-
- ReflectNestedObjectArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B1
-
- ReflectNestedObjectArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B2
-
- ReflectNestedObjectArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B3
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B1
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B3
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B1
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B3
-
- ReflectRecordTest - Class in org.apache.avro.perf.test.reflect
-
- ReflectRecordTest() - Constructor for class org.apache.avro.perf.test.reflect.ReflectRecordTest
-
- ReflectRecordTest.TestStateDecode - Class in org.apache.avro.perf.test.reflect
-
- ReflectRecordTest.TestStateEncode - Class in org.apache.avro.perf.test.reflect
-
- ReflectRecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_decode_jmhTest
-
- ReflectRecordTest_encode_jmhTest - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_encode_jmhTest
-
- ReflectRecordTest_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType
-
- ReflectRecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B1
-
- ReflectRecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B2
-
- ReflectRecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B3
-
- ReflectRecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType
-
- ReflectRecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B1
-
- ReflectRecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B2
-
- ReflectRecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B3
-
- ReflectRecordTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType
-
- ReflectRecordTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B1
-
- ReflectRecordTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B2
-
- ReflectRecordTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.reflect.generated
-
- ReflectRecordTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B3
-
- ReflectRequestor - Class in org.apache.avro.ipc.reflect
-
- ReflectRequestor(Class<?>, Transceiver) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
-
- ReflectRequestor(Protocol, Transceiver) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
-
- ReflectRequestor(Class<?>, Transceiver, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
-
- ReflectRequestor(Protocol, Transceiver, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectRequestor
-
- ReflectResponder - Class in org.apache.avro.ipc.reflect
-
- ReflectResponder(Class, Object) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
-
- ReflectResponder(Protocol, Object) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
-
- ReflectResponder(Class, Object, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
-
- ReflectResponder(Protocol, Object, ReflectData) - Constructor for class org.apache.avro.ipc.reflect.ReflectResponder
-
- register(String, LogicalTypes.LogicalTypeFactory) - Static method in class org.apache.avro.LogicalTypes
-
Register a logical type.
- remove() - Method in class org.apache.avro.file.DataFileReader12
-
- remove() - Method in class org.apache.avro.file.DataFileStream
-
Not supported.
- remove(int) - Method in class org.apache.avro.generic.GenericData.Array
-
- remove() - Method in class org.apache.avro.hadoop.io.AvroKeyValue.Iterator
- remove() - Method in class org.apache.avro.mapred.SequenceFileReader
-
- remove(Object) - Method in class org.apache.avro.util.WeakIdentityHashMap
-
- remove() - Method in class org.apache.trevni.avro.AvroColumnReader
-
- remove() - Method in class org.apache.trevni.ColumnValues
-
- RenderableMessage(String) - Constructor for class org.apache.avro.ipc.stats.StatsServlet.RenderableMessage
-
- 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_WORDS - Static variable in class org.apache.avro.specific.SpecificData
-
List of Java reserved words from
https://docs.oracle.com/javase/specs/jls/se8/html/jls-3.html#jls-3.9 combined
with the boolean and null literals.
- 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.Array
-
- 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
-
- resolve(Schema, Schema) - Static method in class org.apache.avro.io.ResolvingDecoder
-
- resolve(Schema, Schema, GenericData) - Static method in class org.apache.avro.Resolver.EnumAdjust
-
- resolve(Schema, Schema, GenericData) - Static method in class org.apache.avro.Resolver.Promote
-
Return a promotion.
- resolve(Schema, Schema, GenericData, Map<Schema.SeenPair, Resolver.Action>) - Static method in class org.apache.avro.Resolver.ReaderUnion
-
- 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) - Static method in class org.apache.avro.Resolver
-
Uses GenericData.get() for the data param.
- resolve(Schema, Schema, GenericData, Map<Schema.SeenPair, Resolver.Action>) - Static method in class org.apache.avro.Resolver.WriterUnion
-
- 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
-
- 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
-
- 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
-
- ResolvingRecordTest - Class in org.apache.avro.perf.test.record
-
- ResolvingRecordTest() - Constructor for class org.apache.avro.perf.test.record.ResolvingRecordTest
-
- ResolvingRecordTest.TestStateDecode - Class in org.apache.avro.perf.test.record
-
- ResolvingRecordTest_decode_jmhTest - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_decode_jmhTest
-
- ResolvingRecordTest_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType
-
- ResolvingRecordTest_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B1
-
- ResolvingRecordTest_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B2
-
- ResolvingRecordTest_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B3
-
- ResolvingRecordTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType
-
- ResolvingRecordTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B1
-
- ResolvingRecordTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
-
- ResolvingRecordTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.record.generated
-
- ResolvingRecordTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B3
-
- 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
- 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.Array
-
- rindex - Variable in class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
-
- rindex - Variable in class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
-
- RPCContext - Class in org.apache.avro.ipc
-
This class represents the context of an RPC call or RPC handshake.
- RPCContext() - Constructor for class org.apache.avro.ipc.RPCContext
-
- rpcMetaPlugins - Variable in class org.apache.avro.ipc.Requestor
-
- rpcMetaPlugins - Variable in class org.apache.avro.ipc.Responder
-
- RPCPlugin - Class in org.apache.avro.ipc
-
An instrumentation API for RPC metadata.
- RPCPlugin() - Constructor for class org.apache.avro.ipc.RPCPlugin
-
- RpcProtocolTool - Class in org.apache.avro.tool
-
Tool to grab the protocol from a remote running service.
- RpcProtocolTool() - Constructor for class org.apache.avro.tool.RpcProtocolTool
-
- RpcReceiveTool - Class in org.apache.avro.tool
-
Receives one RPC call and responds.
- RpcReceiveTool() - Constructor for class org.apache.avro.tool.RpcReceiveTool
-
- RpcSendTool - Class in org.apache.avro.tool
-
Sends a single RPC message.
- RpcSendTool() - Constructor for class org.apache.avro.tool.RpcSendTool
-
- run() - Method in class org.apache.avro.ipc.DatagramServer
-
- run() - Method in class org.apache.avro.ipc.SocketServer
-
Deprecated.
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.BinaryFragmentToJsonTool
-
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.CatTool
-
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.ConcatTool
-
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.CreateRandomFileTool
-
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.DataFileGetMetaTool
-
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.DataFileGetSchemaTool
-
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.DataFileReadTool
-
- run(InputStream, PrintStream, PrintStream, List<String>) - Method in class org.apache.avro.tool.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.
- SaslSocketServer - Class in org.apache.avro.ipc
-
- SaslSocketServer(Responder, SocketAddress) - Constructor for class org.apache.avro.ipc.SaslSocketServer
-
- SaslSocketServer(Responder, SocketAddress, String, String, String, Map<String, ?>, CallbackHandler) - Constructor for class org.apache.avro.ipc.SaslSocketServer
-
- SaslSocketTransceiver - Class in org.apache.avro.ipc
-
- SaslSocketTransceiver(SocketAddress) - Constructor for class org.apache.avro.ipc.SaslSocketTransceiver
-
- SaslSocketTransceiver(SocketAddress, SaslClient) - Constructor for class org.apache.avro.ipc.SaslSocketTransceiver
-
- SaslSocketTransceiver(SocketChannel, SaslServer) - Constructor for class org.apache.avro.ipc.SaslSocketTransceiver
-
- SCHEMA - Static variable in class org.apache.avro.data.Json
-
The schema for Json data.
- schema() - Method in class org.apache.avro.data.RecordBuilderBase
-
- SCHEMA - Static variable in class org.apache.avro.file.DataFileConstants
-
- schema - Variable in class org.apache.avro.reflect.CustomEncoding
-
- Schema - Class in org.apache.avro
-
An abstract data type.
- schema() - Method in class org.apache.avro.Schema.Field
-
- schema - Variable in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
-
Provided avro schema from the context
- SCHEMA$ - Static variable in enum org.apache.avro.ipc.HandshakeMatch
-
- SCHEMA$ - Static variable in class org.apache.avro.ipc.HandshakeRequest
-
- SCHEMA$ - Static variable in class org.apache.avro.ipc.HandshakeResponse
-
- SCHEMA$ - Static variable in class org.apache.avro.ipc.MD5
-
- SCHEMA$ - Static variable in enum org.apache.avro.mapred.tether.TaskType
-
- 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 a schema.
- SCHEMA_KEY - Static variable in class org.apache.trevni.avro.AvroColumnWriter
-
- SchemaBuilder - Class in org.apache.avro
-
A fluent interface for building
Schema
instances.
- SchemaBuilder.ArrayBuilder<R> - Class in org.apache.avro
-
Builds an Avro Array type with optional properties.
- SchemaBuilder.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
-
- SchemaBuilder.FieldDefault<R,S extends SchemaBuilder.FieldDefault<R,S>> - Class in org.apache.avro
-
Abstract base class for field defaults.
- SchemaBuilder.FieldTypeBuilder<R> - Class in org.apache.avro
-
- SchemaBuilder.FixedBuilder<R> - Class in org.apache.avro
-
Builds an Avro Fixed type with optional properties, namespace, doc, and
aliases.
- SchemaBuilder.FixedDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.FloatBuilder<R> - Class in org.apache.avro
-
Builds an Avro float type with optional properties.
- SchemaBuilder.FloatDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.GenericDefault<R> - Class in org.apache.avro
-
- SchemaBuilder.IntBuilder<R> - Class in org.apache.avro
-
Builds an Avro int type with optional properties.
- SchemaBuilder.IntDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.LongBuilder<R> - Class in org.apache.avro
-
Builds an Avro long type with optional properties.
- SchemaBuilder.LongDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.MapBuilder<R> - Class in org.apache.avro
-
Builds an Avro Map type with optional properties.
- SchemaBuilder.MapDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.NamedBuilder<S extends SchemaBuilder.NamedBuilder<S>> - Class in org.apache.avro
-
An abstract type that provides builder methods for configuring the name, doc,
and aliases of all Avro types that have names (fields, Fixed, Record, and
Enum).
- SchemaBuilder.NamespacedBuilder<R,S extends SchemaBuilder.NamespacedBuilder<R,S>> - Class in org.apache.avro
-
An abstract type that provides builder methods for configuring the namespace
for all Avro types that have namespaces (Fixed, Record, and Enum).
- SchemaBuilder.NullBuilder<R> - Class in org.apache.avro
-
Builds an Avro null type with optional properties.
- SchemaBuilder.NullDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.PropBuilder<S extends SchemaBuilder.PropBuilder<S>> - Class in org.apache.avro
-
An abstract builder for all Avro types.
- SchemaBuilder.RecordBuilder<R> - Class in org.apache.avro
-
- SchemaBuilder.RecordDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.StringBldr<R> - Class in org.apache.avro
-
Builds an Avro string type with optional properties.
- SchemaBuilder.StringDefault<R> - Class in org.apache.avro
-
Choose whether to use a default value for the field or not.
- SchemaBuilder.TypeBuilder<R> - Class in org.apache.avro
-
A Builder for creating any Avro schema type.
- SchemaBuilder.UnionAccumulator<R> - Class in org.apache.avro
-
Accumulates all of the types in a union.
- SchemaBuilder.UnionFieldTypeBuilder<R> - Class in org.apache.avro
-
Builder for a union field.
- SchemaBuilderException - Exception in org.apache.avro
-
Thrown for errors building schemas.
- SchemaBuilderException(Throwable) - Constructor for exception org.apache.avro.SchemaBuilderException
-
- SchemaBuilderException(String) - Constructor for exception org.apache.avro.SchemaBuilderException
-
- SchemaCompatibility - Class in org.apache.avro
-
Evaluate the compatibility between a reader schema and a writer schema.
- SchemaCompatibility.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
-
- 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
-
- 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 in org.apache.avro
-
Thrown for errors parsing schemas and protocols.
- SchemaParseException(Throwable) - Constructor for exception org.apache.avro.SchemaParseException
-
- SchemaParseException(String) - Constructor for exception org.apache.avro.SchemaParseException
-
- Schemas - Class in org.apache.avro.compiler.schema
-
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
-
- SchemaValidationException - Exception in org.apache.avro
-
- SchemaValidationException(Schema, Schema) - Constructor for exception org.apache.avro.SchemaValidationException
-
- SchemaValidationException(Schema, Schema, Throwable) - Constructor for exception 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
-
- SchemaVisitorAction - Enum in org.apache.avro.compiler.schema
-
- seek(long) - Method in class org.apache.avro.file.DataFileReader
-
- seek(long) - Method in class org.apache.avro.file.DataFileReader12
-
- 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
-
- SeekableByteArrayInput(byte[]) - Constructor for class org.apache.avro.file.SeekableByteArrayInput
-
- SeekableFileInput - Class in org.apache.avro.file
-
- 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
-
- 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
-
- SequenceFileInputFormat<K,V> - Class in org.apache.avro.mapred
-
- SequenceFileInputFormat() - Constructor for class org.apache.avro.mapred.SequenceFileInputFormat
-
- SequenceFileReader<K,V> - Class in org.apache.avro.mapred
-
- 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
-
- SequenceFileRecordReader(JobConf, FileSplit) - Constructor for class org.apache.avro.mapred.SequenceFileRecordReader
-
- serialize(AvroWrapper<T>) - Method in class org.apache.avro.hadoop.io.AvroSerializer
- Server - Interface in org.apache.avro.ipc
-
A server listening on a port.
- serverConnecting(RPCContext) - Method in class org.apache.avro.ipc.RPCPlugin
-
Called on the server during the RPC handshake
- 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, T) - Method in class org.apache.avro.generic.GenericData.Array
-
- set(String, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Sets the value of a field.
- set(Schema.Field, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Sets the value of a field.
- set(int, Object) - Method in class org.apache.avro.generic.GenericRecordBuilder
-
Sets the value of a field.
- set(K, V) - Method in class org.apache.avro.mapred.Pair
-
Set both the key and value.
- set(String) - Method in class org.apache.avro.util.Utf8
-
Set to the contents of a String.
- set(Utf8) - Method in class org.apache.avro.util.Utf8
-
- set(String, byte[]) - Method in class org.apache.trevni.MetaData
-
Set a metadata property to a binary value.
- set(String, String) - Method in class org.apache.trevni.MetaData
-
Set a metadata property to a String value.
- set(String, long) - Method in class org.apache.trevni.MetaData
-
Set a metadata property to a long value.
- 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(CodecFactory) - Method in class org.apache.avro.file.DataFileWriter
-
Configures this writer to use the given codec.
- setCodec(String) - Method in class org.apache.trevni.MetaData
-
Set the compression codec name.
- setCombinerClass(JobConf, Class<? extends AvroReducer>) - Static method in class org.apache.avro.mapred.AvroJob
-
Configure a job's combiner implementation.
- 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.
- 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
-
- 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
-
- setField(Object, String, int, Object, Object) - Method in class org.apache.avro.generic.GenericData
-
- setField(Object, String, int, Object) - Method in class org.apache.avro.protobuf.ProtobufData
-
- setField(Object, String, int, Object, Object) - Method in class org.apache.avro.protobuf.ProtobufData
-
- setField(Object, String, int, Object) - Method in class org.apache.avro.reflect.ReflectData
-
- setField(Object, String, int, Object, Object) - Method in class org.apache.avro.reflect.ReflectData
-
- setField(Object, String, int, Object) - Method in class org.apache.avro.thrift.ThriftData
-
- setField(Object, String, int, Object, Object) - Method in class org.apache.avro.thrift.ThriftData
-
- setFields(List<Schema.Field>) - Method in class org.apache.avro.Schema
-
If this is a record, set its fields.
- setFieldVisibility(SpecificCompiler.FieldVisibility) - Method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Sets the field visibility option.
- setFile(File) - Method in class org.apache.avro.compiler.specific.ProtocolTask
-
Set the schema file.
- setFlushOnEveryBlock(boolean) - Method in class org.apache.avro.file.DataFileWriter
-
Set whether this writer should flush the block to the stream every time a
sync marker is written.
- 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.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
-
- 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
-
- setMeta(String, byte[]) - Method in class org.apache.avro.file.DataFileWriter
-
Set a metadata property.
- setMeta(String, String) - Method in class org.apache.avro.file.DataFileWriter
-
Set a metadata property.
- setMeta(String, long) - Method in class org.apache.avro.file.DataFileWriter
-
Set a metadata property.
- setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeRequest.Builder
-
Sets the value of the 'meta' field.
- setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeRequest
-
Sets the value of the 'meta' field.
- setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeResponse.Builder
-
Sets the value of the 'meta' field.
- setMeta(Map<String, ByteBuffer>) - Method in class org.apache.avro.ipc.HandshakeResponse
-
Sets the value of the 'meta' field.
- setMeta(JobConf, String, String) - Static method in class org.apache.trevni.avro.AvroTrevniOutputFormat
-
Add metadata to job output files.
- setModel(GenericData) - Method in class org.apache.trevni.avro.AvroColumnReader.Params
-
Set data representation.
- 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, String) - Static method in class org.apache.avro.mapred.AvroJob
-
Add metadata to job output files.
- setOutputMeta(JobConf, String, long) - Static method in class org.apache.avro.mapred.AvroJob
-
Add metadata to job output files.
- setOutputMeta(JobConf, String, byte[]) - Static method in class org.apache.avro.mapred.AvroJob
-
Add metadata to job output files.
- setOutputSchema(JobConf, Schema) - Static method in class org.apache.avro.mapred.AvroJob
-
Configure a job's output schema.
- setOutputValueSchema(Job, Schema) - Static method in class org.apache.avro.mapreduce.AvroJob
-
Sets the job output value schema.
- setParent(ColumnMetaData) - Method in class org.apache.trevni.ColumnMetaData
-
Set this column's parent.
- setProtocol(JobConf, String) - Static method in class org.apache.avro.mapred.tether.TetherJob
-
Determines which transport protocol (e.g http or sasl) used to communicate
between the parent and subprocess
- setReducerClass(JobConf, Class<? extends AvroReducer>) - Static method in class org.apache.avro.mapred.AvroJob
-
Configure a job's reducer implementation.
- setReflect(JobConf) - Static method in class org.apache.avro.mapred.AvroJob
-
Indicate that all a job's data should use the reflect representation.
- 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
-
- 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.generated.ArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B2
-
- setupInvocationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B2
-
- setupIterationMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutex - Variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BooleanTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.BytesTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.DoubleTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.ExtendedEnumTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.FloatTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.IntTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.LongTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.MapTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.basic.generated.UnchangedUnionTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedFakeTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericNestedTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericStringTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithDefaultTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.generic.generated.GenericWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithDefaultTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithOutOfOrderTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.RecordWithPromotionTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ResolvingRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.record.generated.ValidatingRecordTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectBigRecordTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectDoubleArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectIntArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayBlockedTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLargeFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectLongArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedFloatArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectNestedObjectArrayTest_TestStateEncode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateDecode_jmhType_B2
-
- setupTrialMutexUpdater - Static variable in class org.apache.avro.perf.test.reflect.generated.ReflectRecordTest_TestStateEncode_jmhType_B2
-
- setValidate(boolean) - Method in class org.apache.avro.Schema.Parser
-
Enable or disable name validation.
- setValidateDefaults(boolean) - Method in class org.apache.avro.Schema.Parser
-
Enable or disable default value validation.
- setValue(Object) - Method in interface org.apache.avro.data.ErrorBuilder
-
Sets the value
- setValue(V) - Method in class org.apache.avro.hadoop.io.AvroKeyValue
-
Sets the value.
- setValue(V) - Method in class org.apache.avro.reflect.MapEntry
-
- setValue(Object) - Method in class org.apache.avro.specific.SpecificErrorBuilderBase
-
- setValueReaderSchema(Configuration, Schema) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
-
Sets the reader schema of the AvroValue datum that is being
serialized/deserialized.
- setValueWriterSchema(Configuration, Schema) - Static method in class org.apache.avro.hadoop.io.AvroSerialization
-
Sets the writer schema of the AvroValue datum that is being
serialized/deserialized.
- size() - Method in class org.apache.avro.generic.GenericData.Array
-
- size() - Method in class org.apache.avro.io.parsing.Symbol.Alternative
-
- size - Variable in class org.apache.avro.io.parsing.Symbol.IntCheckAction
-
- size() - Method in class org.apache.avro.io.parsing.Symbol.Sequence
-
- size(int) - Method in class org.apache.avro.SchemaBuilder.FixedBuilder
-
Configure this fixed type's size, and end its configuration.
- size() - Method in class org.apache.avro.util.WeakIdentityHashMap
-
- sizeEstimate() - Method in class org.apache.trevni.avro.AvroColumnWriter
-
Return the approximate size of the file that will be written.
- sizeEstimate() - Method in class org.apache.trevni.ColumnFileWriter
-
Return the approximate size of the file that will be written.
- skip(Schema, Decoder) - Static method in class org.apache.avro.generic.GenericDatumReader
-
Skip an instance of a schema.
- Skip(Schema, GenericData) - Constructor for class org.apache.avro.Resolver.Skip
-
- skip(long) - Method in class org.apache.avro.util.ReusableByteBufferInputStream
-
- skipAction() - Method in interface org.apache.avro.io.parsing.SkipParser.SkipHandler
-
Skips the action at the top of the stack.
- skipAction(Symbol) - Static method in class org.apache.avro.io.parsing.Symbol
-
- SkipAction(Symbol) - Constructor for class org.apache.avro.io.parsing.Symbol.SkipAction
-
Deprecated.
- skipAction() - Method in class org.apache.avro.io.ParsingDecoder
-
- skipAction() - Method in class org.apache.avro.io.ResolvingDecoder
-
- skipArray() - Method in class org.apache.avro.io.BinaryDecoder
-
- skipArray() - Method in class org.apache.avro.io.Decoder
-
Used for quickly skipping through an array.
- skipArray() - Method in class org.apache.avro.io.JsonDecoder
-
- skipArray() - Method in class org.apache.avro.io.ValidatingDecoder
-
- skipBytes() - Method in class org.apache.avro.io.BinaryDecoder
-
- skipBytes() - Method in class org.apache.avro.io.Decoder
-
- 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(int) - Method in class org.apache.avro.io.BinaryDecoder
-
- skipFixed(int) - Method in class org.apache.avro.io.Decoder
-
Discards fixed sized binary object.
- skipFixed(int) - Method in class org.apache.avro.io.JsonDecoder
-
- skipFixed() - Method in class org.apache.avro.io.JsonDecoder
-
- skipFixed() - Method in class org.apache.avro.io.ParsingDecoder
-
- skipFixed(int) - Method in class org.apache.avro.io.ValidatingDecoder
-
- skipFixed() - Method in class org.apache.avro.io.ValidatingDecoder
-
- skipLong(byte[], int) - Static method in class org.apache.avro.io.BinaryData
-
Skip a binary-encoded long, returning the position after it.
- skipMap() - Method in class org.apache.avro.io.BinaryDecoder
-
- skipMap() - Method in class org.apache.avro.io.Decoder
-
- 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
-
- 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
or readXyz
methods on
this
, until the parser stack reaches the target level.
- skipTopSymbol() - Method in interface org.apache.avro.io.parsing.SkipParser.SkipHandler
-
Skips the symbol at the top of the stack.
- skipTopSymbol() - Method in class org.apache.avro.io.ParsingDecoder
-
- SmallLongTest - Class in org.apache.avro.perf.test.basic
-
- SmallLongTest() - Constructor for class org.apache.avro.perf.test.basic.SmallLongTest
-
- SmallLongTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
-
- SmallLongTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
-
- SmallLongTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_decode_jmhTest
-
- SmallLongTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_encode_jmhTest
-
- SmallLongTest_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType
-
- SmallLongTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B1
-
- SmallLongTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B2
-
- SmallLongTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_jmhType_B3
-
- SmallLongTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType
-
- SmallLongTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B1
-
- SmallLongTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B2
-
- SmallLongTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateDecode_jmhType_B3
-
- SmallLongTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType
-
- SmallLongTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B1
-
- SmallLongTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B2
-
- SmallLongTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- SmallLongTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.SmallLongTest_TestStateEncode_jmhType_B3
-
- 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
-
- SocketServer(Responder, SocketAddress) - Constructor for class org.apache.avro.ipc.SocketServer
-
Deprecated.
- SocketTransceiver - Class in org.apache.avro.ipc
-
- SocketTransceiver(SocketAddress) - Constructor for class org.apache.avro.ipc.SocketTransceiver
-
Deprecated.
- SocketTransceiver(SocketChannel) - Constructor for class org.apache.avro.ipc.SocketTransceiver
-
Deprecated.
- SortedKeyValueFile - Class in org.apache.avro.hadoop.file
-
A SortedKeyValueFile is an indexed Avro container file of KeyValue records
sorted by key.
- SortedKeyValueFile() - Constructor for class org.apache.avro.hadoop.file.SortedKeyValueFile
-
- SortedKeyValueFile.Reader<K,V> - Class in org.apache.avro.hadoop.file
-
Reads a SortedKeyValueFile by loading the key index into memory.
- SortedKeyValueFile.Reader.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.
- SpecificCompiler - Class in org.apache.avro.compiler.specific
-
Generate specific Java interfaces and classes for protocols and schemas.
- SpecificCompiler(Protocol) - Constructor for class org.apache.avro.compiler.specific.SpecificCompiler
-
- SpecificCompiler(Schema) - Constructor for class org.apache.avro.compiler.specific.SpecificCompiler
-
- SpecificCompiler.FieldVisibility - Enum in org.apache.avro.compiler.specific
-
- 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
-
- 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
-
- SpecificDatumWriter<T> - Class in org.apache.avro.specific
-
- SpecificDatumWriter() - Constructor for class org.apache.avro.specific.SpecificDatumWriter
-
- SpecificDatumWriter(Class<T>) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
-
- SpecificDatumWriter(Schema) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
-
- SpecificDatumWriter(Schema, SpecificData) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
-
- SpecificDatumWriter(SpecificData) - Constructor for class org.apache.avro.specific.SpecificDatumWriter
-
- SpecificErrorBuilderBase<T extends SpecificExceptionBase> - Class in org.apache.avro.specific
-
Abstract base class for specific ErrorBuilder implementations.
- SpecificErrorBuilderBase(Schema) - Constructor for class org.apache.avro.specific.SpecificErrorBuilderBase
-
Creates a SpecificErrorBuilderBase for building errors of the given type.
- SpecificErrorBuilderBase(SpecificErrorBuilderBase<T>) - Constructor for class org.apache.avro.specific.SpecificErrorBuilderBase
-
SpecificErrorBuilderBase copy constructor.
- SpecificErrorBuilderBase(T) - Constructor for class org.apache.avro.specific.SpecificErrorBuilderBase
-
Creates a SpecificErrorBuilderBase by copying an existing error instance.
- SpecificExceptionBase - Exception in org.apache.avro.specific
-
Base class for specific exceptions.
- SpecificExceptionBase() - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
-
- SpecificExceptionBase(Throwable) - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
-
- SpecificExceptionBase(Object) - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
-
- SpecificExceptionBase(Object, Throwable) - Constructor for exception org.apache.avro.specific.SpecificExceptionBase
-
- SpecificFixed - Class in org.apache.avro.specific
-
Base class for generated fixed-sized data classes.
- SpecificFixed() - Constructor for class org.apache.avro.specific.SpecificFixed
-
- SpecificFixed(byte[]) - Constructor for class org.apache.avro.specific.SpecificFixed
-
- SpecificRecord - Interface in org.apache.avro.specific
-
Implemented by generated record classes.
- SpecificRecordBase - Class in org.apache.avro.specific
-
Base class for generated record classes.
- SpecificRecordBase() - Constructor for class org.apache.avro.specific.SpecificRecordBase
-
- SpecificRecordBuilderBase<T extends SpecificRecord> - Class in org.apache.avro.specific
-
Abstract base class for specific RecordBuilder implementations.
- SpecificRecordBuilderBase(Schema) - Constructor for class org.apache.avro.specific.SpecificRecordBuilderBase
-
Creates a SpecificRecordBuilderBase for building records of the given type.
- SpecificRecordBuilderBase(SpecificRecordBuilderBase<T>) - Constructor for class org.apache.avro.specific.SpecificRecordBuilderBase
-
SpecificRecordBuilderBase copy constructor.
- SpecificRecordBuilderBase(T) - Constructor for class org.apache.avro.specific.SpecificRecordBuilderBase
-
Creates a SpecificRecordBuilderBase by copying an existing record instance.
- SpecificRequestor - Class in org.apache.avro.ipc.specific
-
- SpecificRequestor(Class<?>, Transceiver) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
-
- SpecificRequestor(Protocol, Transceiver) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
-
- SpecificRequestor(Class<?>, Transceiver, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
-
- SpecificRequestor(Protocol, Transceiver, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificRequestor
-
- SpecificResponder - Class in org.apache.avro.ipc.specific
-
- SpecificResponder(Class, Object) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
-
- SpecificResponder(Protocol, Object) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
-
- SpecificResponder(Class, Object, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
-
- SpecificResponder(Protocol, Object, SpecificData) - Constructor for class org.apache.avro.ipc.specific.SpecificResponder
-
- stack - Variable in class org.apache.avro.io.parsing.Parser
-
- start() - Method in class org.apache.avro.ipc.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
-
- 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(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.
- StatsPlugin() - Constructor for class org.apache.avro.ipc.stats.StatsPlugin
-
Construct a plugin with default (system) ticks, and default histogram
segmentation.
- StatsServer - Class in org.apache.avro.ipc.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
-
Transmit outputs from a map or reduce task to parent.
- 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.AvroRequestMarshaller
-
- stream(Object) - Method in class org.apache.avro.grpc.AvroResponseMarshaller
-
- 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.
- StringTest - Class in org.apache.avro.perf.test.basic
-
- StringTest() - Constructor for class org.apache.avro.perf.test.basic.StringTest
-
- StringTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
-
- StringTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
-
- StringTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_decode_jmhTest
-
- StringTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_encode_jmhTest
-
- StringTest_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_jmhType
-
- StringTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B1
-
- StringTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B2
-
- StringTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_jmhType_B3
-
- StringTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType
-
- StringTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B1
-
- StringTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B2
-
- StringTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateDecode_jmhType_B3
-
- StringTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType
-
- StringTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B1
-
- StringTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B2
-
- StringTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.generated
-
- StringTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.generated.StringTest_TestStateEncode_jmhType_B3
-
- 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
-
- 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(long) - Method in class org.apache.avro.file.DataFileReader
-
Move to the next synchronization point after a position.
- sync(long) - Method in class org.apache.avro.file.DataFileReader12
-
Move to the next synchronization point after a position.
- sync() - Method in class org.apache.avro.file.DataFileWriter
-
- sync(long) - Method in interface org.apache.avro.file.FileReader
-
Move to the next synchronization point after a position.
- sync() - Method in interface org.apache.avro.file.Syncable
-
Sync the file to disk.
- sync() - Method in class org.apache.avro.file.SyncableFileOutputStream
-
Sync the file to disk.
- sync(long) - Method in class org.apache.avro.mapred.SequenceFileReader
-
- sync() - Method in class org.apache.avro.mapreduce.AvroKeyRecordWriter
-
Return the current position as a value that may be passed to
DataFileReader.seek(long).
- sync() - Method in class org.apache.avro.mapreduce.AvroKeyValueRecordWriter
-
Return the current position as a value that may be passed to
DataFileReader.seek(long).
- sync(String, String) - Method in class org.apache.avro.mapreduce.AvroMultipleOutputs
-
Gets the record writer from job's output format.
- sync() - Method in interface org.apache.avro.mapreduce.Syncable
-
Return the current position as a value that may be passed to
DataFileReader.seek(long).
- SYNC_INTERVAL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
-
The configuration key for Avro sync interval.
- SYNC_SIZE - Static variable in class org.apache.avro.file.DataFileConstants
-
- Syncable - Interface in org.apache.avro.file
-
- Syncable - Interface in org.apache.avro.mapreduce
-
- SyncableFileOutputStream - Class in org.apache.avro.file
-
An implementation of
Syncable which writes to a file.
- SyncableFileOutputStream(String) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
- SyncableFileOutputStream(File) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
- SyncableFileOutputStream(String, boolean) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
Creates an instance of
SyncableFileOutputStream with the given
name and optionally append to the file if it already exists.
- SyncableFileOutputStream(File, boolean) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
Creates an instance of
SyncableFileOutputStream that writes to
the file represented by the given
File instance and optionally
append to the file if it already exists.
- SyncableFileOutputStream(FileDescriptor) - Constructor for class org.apache.avro.file.SyncableFileOutputStream
-
- 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.