- abort() - Method in interface org.apache.avro.mapred.tether.InputProtocol
-
Called to abort the task.
- AbstractAvroMojo - Class in org.apache.avro.mojo
-
Base for Avro Compiler Mojos.
- AbstractAvroMojo() - Constructor for class org.apache.avro.mojo.AbstractAvroMojo
-
- accept(Class<?>) - Method in class org.apache.avro.hadoop.io.AvroSerialization
- accept(Class<?>) - Method in class org.apache.avro.mapred.AvroSerialization
-
- ACCESSOR_MUTATOR_RESERVED_WORDS - Static variable in class org.apache.avro.compiler.specific.SpecificCompiler
-
- 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
-
- ArrayPositionPredicate - Class in org.apache.avro.path
-
Returns items by their position (numeric index) in an array
- ArrayPositionPredicate(long) - Constructor for class org.apache.avro.path.ArrayPositionPredicate
-
- arraySize - Variable in class org.apache.avro.perf.test.BasicArrayState
-
- ArrayTest - Class in org.apache.avro.perf.test.basic
-
- ArrayTest() - Constructor for class org.apache.avro.perf.test.basic.ArrayTest
-
- ArrayTest.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.jmh_generated
-
- ArrayTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- ArrayTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_encode_jmhTest
-
- ArrayTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType
-
- ArrayTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B1
-
- ArrayTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B2
-
- ArrayTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_jmhType_B3
-
- ArrayTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType
-
- ArrayTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B1
-
- ArrayTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B2
-
- ArrayTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateDecode_jmhType_B3
-
- ArrayTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType
-
- ArrayTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B1
-
- ArrayTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B2
-
- ArrayTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- ArrayTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_TestStateEncode_jmhType_B3
-
- asByteBuffer() - Method in class org.apache.avro.util.NonCopyingByteArrayOutputStream
-
Get the contents of this ByteArrayOutputStream wrapped as a ByteBuffer.
- 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
-
Called when a task's input is complete.
- complete() - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Called when a task's output has completed without error.
- compress(ByteBuffer) - Method in class org.apache.avro.file.BZip2Codec
-
- compress(ByteBuffer) - Method in class org.apache.avro.file.Codec
-
Compresses the input data
- compress(ByteBuffer) - Method in class org.apache.avro.file.DeflateCodec
-
- compress(ByteBuffer) - Method in class org.apache.avro.file.SnappyCodec
-
- compress(ByteBuffer) - Method in class org.apache.avro.file.XZCodec
-
- compress(ByteBuffer) - Method in class org.apache.avro.file.ZstandardCodec
-
- computeIfAbsent(ConcurrentMap<K, V>, K, Function<K, V>) - Static method in class org.apache.avro.util.MapUtil
-
A temporary workaround for Java 8 specific performance issue JDK-8161372
.
This class should be removed once we drop Java 8 support.
- computeOffset(ByteBuffer) - Static method in class org.apache.avro.file.Codec
-
- 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
-
Configure the task.
- configure(int) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Configure task.
- configureBlockSize(int) - Method in class org.apache.avro.io.EncoderFactory
-
Configures this factory to construct blocking BinaryEncoders with the
specified block buffer size.
- configureBufferSize(int) - Method in class org.apache.avro.io.EncoderFactory
-
Configures this factory to use the specified buffer size when creating
Encoder instances that buffer their output.
- configureDecoderBufferSize(int) - Method in class org.apache.avro.io.DecoderFactory
-
Configures this factory to use the specified buffer size when creating
Decoder instances that buffer their input.
- 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 an 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 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
-
Increment a task/job counter.
- 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
-
- d1 - Variable in class org.apache.avro.perf.test.BigRecord
-
- d11 - Variable in class org.apache.avro.perf.test.BigRecord
-
- data() - Method in class org.apache.avro.data.RecordBuilderBase
-
- DATA_FILENAME - Static variable in class org.apache.avro.hadoop.file.SortedKeyValueFile
-
The name of the data file within the SortedKeyValueFile directory.
- DataFileConstants - Class in org.apache.avro.file
-
Constants used in data files.
- DataFileGetMetaTool - Class in org.apache.avro.tool
-
Reads a data file to get its metadata.
- DataFileGetMetaTool() - Constructor for class org.apache.avro.tool.DataFileGetMetaTool
-
- DataFileGetSchemaTool - Class in org.apache.avro.tool
-
Reads a data file to get its schema.
- DataFileGetSchemaTool() - Constructor for class org.apache.avro.tool.DataFileGetSchemaTool
-
- DataFileReader<D> - Class in org.apache.avro.file
-
- DataFileReader(File, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileReader
-
Construct a reader for a file.
- DataFileReader(SeekableInput, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileReader
-
Construct a reader for a file.
- DataFileReader(SeekableInput, DatumReader<D>, boolean, byte[]) - Constructor for class org.apache.avro.file.DataFileReader
-
Construct a reader for a file.
- DataFileReader(SeekableInput, DatumReader<D>, DataFileStream.Header) - Constructor for class org.apache.avro.file.DataFileReader
-
- DataFileReader12<D> - Class in org.apache.avro.file
-
Read files written by Avro version 1.2.
- DataFileReader12(SeekableInput, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileReader12
-
Construct a reader for a file.
- DataFileReadTool - Class in org.apache.avro.tool
-
Reads a data file and dumps to JSON
- DataFileReadTool() - Constructor for class org.apache.avro.tool.DataFileReadTool
-
- DataFileRepairTool - Class in org.apache.avro.tool
-
Recovers data from a corrupt Avro Data file
- DataFileRepairTool() - Constructor for class org.apache.avro.tool.DataFileRepairTool
-
- DataFileStream<D> - Class in org.apache.avro.file
-
- DataFileStream(InputStream, DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileStream
-
Construct a reader for an input stream.
- DataFileStream(DatumReader<D>) - Constructor for class org.apache.avro.file.DataFileStream
-
create an uninitialized DataFileStream
- DataFileStream.Header - Class in org.apache.avro.file
-
A handle that can be used to reopen a DataFile without re-reading the header
of the stream.
- DataFileWriter<D> - Class in org.apache.avro.file
-
Stores in a file a sequence of data conforming to a schema.
- DataFileWriter(DatumWriter<D>) - Constructor for class org.apache.avro.file.DataFileWriter
-
Construct a writer, not yet open.
- DataFileWriter.AppendWriteException - Exception in org.apache.avro.file
-
- DataFileWriteTool - Class in org.apache.avro.tool
-
Reads new-line delimited JSON records and writers an Avro data file.
- DataFileWriteTool() - Constructor for class org.apache.avro.tool.DataFileWriteTool
-
- DatagramServer - Class in org.apache.avro.ipc
-
A datagram-based server implementation.
- DatagramServer(Responder, SocketAddress) - Constructor for class org.apache.avro.ipc.DatagramServer
-
- DatagramTransceiver - Class in org.apache.avro.ipc
-
- DatagramTransceiver(SocketAddress) - Constructor for class org.apache.avro.ipc.DatagramTransceiver
-
- DatagramTransceiver(DatagramChannel) - Constructor for class org.apache.avro.ipc.DatagramTransceiver
-
- date() - Static method in class org.apache.avro.LogicalTypes
-
- DateAsLongEncoding - Class in org.apache.avro.reflect
-
This encoder/decoder writes a java.util.Date object as a long to avro and
reads a Date object from long.
- DateAsLongEncoding() - Constructor for class org.apache.avro.reflect.DateAsLongEncoding
-
- DateConversion() - Constructor for class org.apache.avro.data.TimeConversions.DateConversion
-
- datum() - Method in class org.apache.avro.mapred.AvroWrapper
-
Return the wrapped datum.
- datum(T) - Method in class org.apache.avro.mapred.AvroWrapper
-
Set the wrapped datum.
- DatumReader<D> - Interface in org.apache.avro.io
-
Read data of a schema.
- DatumWriter<D> - Interface in org.apache.avro.io
-
Write data of a schema.
- decimal(int) - Static method in class org.apache.avro.LogicalTypes
-
Create a Decimal LogicalType with the given precision and scale 0
- decimal(int, int) - Static method in class org.apache.avro.LogicalTypes
-
Create a Decimal LogicalType with the given precision and scale
- DecimalConversion() - Constructor for class org.apache.avro.Conversions.DecimalConversion
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.avro.ipc.netty.NettyTransportCodec.NettyFrameDecoder
-
decode buffer to NettyDataPack
- decode(InputStream, D) - Method in class org.apache.avro.message.BinaryMessageDecoder
-
- decode(InputStream) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
-
- decode(ByteBuffer) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
-
- decode(byte[]) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
-
- decode(ByteBuffer, D) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
-
- decode(byte[], D) - Method in class org.apache.avro.message.MessageDecoder.BaseDecoder
-
- decode(InputStream) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from an InputStream.
- decode(InputStream, D) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from an InputStream.
- decode(ByteBuffer) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a ByteBuffer.
- decode(ByteBuffer, D) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a ByteBuffer.
- decode(byte[]) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a byte array.
- decode(byte[], D) - Method in interface org.apache.avro.message.MessageDecoder
-
Deserialize a single datum from a byte array.
- decode(InputStream, D) - Method in class org.apache.avro.message.RawMessageDecoder
-
- decode(ArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.ArrayTest
-
- decode(BooleanTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.BooleanTest
-
- decode(BytesTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.BytesTest
-
- decode(DoubleTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.DoubleTest
-
- decode(Blackhole, ExtendedEnumTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest
-
- decode(FloatTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.FloatTest
-
- decode(IntTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.IntTest
-
- decode(LongTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.LongTest
-
- decode(MapTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.MapTest
-
- decode(SmallLongTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.SmallLongTest
-
- decode(StringTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.StringTest
-
- decode(Blackhole, UnchangedUnionTest.TestStateDecode) - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest
-
- decode(Blackhole, GenericNestedFakeTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest
-
- decode(Blackhole, GenericNestedTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericNestedTest
-
- decode(Blackhole, GenericStringTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericStringTest
-
- decode(Blackhole, GenericTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericTest
-
- decode(Blackhole, GenericWithDefaultTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest
-
- decode(Blackhole, GenericWithOutOfOrderTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest
-
- decode(Blackhole, GenericWithPromotionTest.TestStateDecode) - Method in class org.apache.avro.perf.test.generic.GenericWithPromotionTest
-
- decode(RecordTest.TestStateDecode, Blackhole) - Method in class org.apache.avro.perf.test.record.RecordTest
-
- decode(RecordWithDefaultTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.RecordWithDefaultTest
-
- decode(RecordWithOutOfOrderTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest
-
- decode(RecordWithPromotionTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.RecordWithPromotionTest
-
- decode(ResolvingRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.ResolvingRecordTest
-
- decode(ValidatingRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest
-
- decode(Blackhole, ReflectBigRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest
-
- decode(Blackhole, ReflectDoubleArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest
-
- decode(Blackhole, ReflectFloatArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest
-
- decode(Blackhole, ReflectIntArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest
-
- decode(Blackhole, ReflectLargeFloatArrayBlockedTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest
-
- decode(Blackhole, ReflectLargeFloatArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest
-
- decode(Blackhole, ReflectLongArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest
-
- decode(Blackhole, ReflectNestedFloatArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest
-
- decode(Blackhole, ReflectNestedObjectArrayTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest
-
- decode(Blackhole, ReflectRecordTest.TestStateDecode) - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_AverageTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_avgt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_sample_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SampleBuffer, int, long, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_SampleTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_SingleShotTime(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_ss_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_Throughput(InfraControl, ThreadParams) - Method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ArrayTest_TestStateDecode_jmhType, ArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BooleanTest_TestStateDecode_jmhType, BooleanTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BooleanTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, BytesTest_TestStateDecode_jmhType, BytesTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.BytesTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, DoubleTest_TestStateDecode_jmhType, DoubleTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ExtendedEnumTest_TestStateDecode_jmhType, ExtendedEnumTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.ExtendedEnumTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, FloatTest_TestStateDecode_jmhType, FloatTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, IntTest_TestStateDecode_jmhType, IntTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.IntTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, LongTest_TestStateDecode_jmhType, LongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.LongTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, MapTest_TestStateDecode_jmhType, MapTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.MapTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, SmallLongTest_TestStateDecode_jmhType, SmallLongTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.SmallLongTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, StringTest_TestStateDecode_jmhType, StringTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.StringTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, UnchangedUnionTest_TestStateDecode_jmhType, UnchangedUnionTest_jmhType) - Static method in class org.apache.avro.perf.test.basic.jmh_generated.UnchangedUnionTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedFakeTest_TestStateDecode_jmhType, GenericNestedFakeTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedFakeTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericNestedTest_TestStateDecode_jmhType, GenericNestedTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericNestedTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericStringTest_TestStateDecode_jmhType, GenericStringTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericStringTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericTest_TestStateDecode_jmhType, GenericTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithDefaultTest_TestStateDecode_jmhType, GenericWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithDefaultTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithOutOfOrderTest_TestStateDecode_jmhType, GenericWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithOutOfOrderTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, GenericWithPromotionTest_TestStateDecode_jmhType, GenericWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.generic.jmh_generated.GenericWithPromotionTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordTest_TestStateDecode_jmhType, RecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithDefaultTest_TestStateDecode_jmhType, RecordWithDefaultTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithDefaultTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithOutOfOrderTest_TestStateDecode_jmhType, RecordWithOutOfOrderTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithOutOfOrderTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, RecordWithPromotionTest_TestStateDecode_jmhType, RecordWithPromotionTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.RecordWithPromotionTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ResolvingRecordTest_TestStateDecode_jmhType, ResolvingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ResolvingRecordTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ValidatingRecordTest_TestStateDecode_jmhType, ValidatingRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.record.jmh_generated.ValidatingRecordTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectBigRecordTest_TestStateDecode_jmhType, ReflectBigRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectBigRecordTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectDoubleArrayTest_TestStateDecode_jmhType, ReflectDoubleArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectDoubleArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectFloatArrayTest_TestStateDecode_jmhType, ReflectFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectFloatArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectIntArrayTest_TestStateDecode_jmhType, ReflectIntArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectIntArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayBlockedTest_TestStateDecode_jmhType, ReflectLargeFloatArrayBlockedTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayBlockedTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLargeFloatArrayTest_TestStateDecode_jmhType, ReflectLargeFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLargeFloatArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectLongArrayTest_TestStateDecode_jmhType, ReflectLongArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectLongArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedFloatArrayTest_TestStateDecode_jmhType, ReflectNestedFloatArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedFloatArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectNestedObjectArrayTest_TestStateDecode_jmhType, ReflectNestedObjectArrayTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectNestedObjectArrayTest_decode_jmhTest
-
- decode_thrpt_jmhStub(InfraControl, RawResults, BenchmarkParams, IterationParams, ThreadParams, Blackhole, Control, int, ReflectRecordTest_TestStateDecode_jmhType, ReflectRecordTest_jmhType) - Static method in class org.apache.avro.perf.test.reflect.jmh_generated.ReflectRecordTest_decode_jmhTest
-
- Decoder - Class in org.apache.avro.io
-
Low-level support for de-serializing Avro values.
- Decoder() - Constructor for class org.apache.avro.io.Decoder
-
- DecoderFactory - Class in org.apache.avro.io
-
A factory for creating and configuring
Decoder
s.
- DecoderFactory() - Constructor for class org.apache.avro.io.DecoderFactory
-
Constructor for factory instances
- decompress(ByteBuffer) - Method in class org.apache.avro.file.BZip2Codec
-
- decompress(ByteBuffer) - Method in class org.apache.avro.file.Codec
-
Decompress the data
- decompress(ByteBuffer) - Method in class org.apache.avro.file.DeflateCodec
-
- decompress(ByteBuffer) - Method in class org.apache.avro.file.SnappyCodec
-
- decompress(ByteBuffer) - Method in class org.apache.avro.file.XZCodec
-
- decompress(ByteBuffer) - Method in class org.apache.avro.file.ZstandardCodec
-
- deepCopy(Schema, T) - Method in class org.apache.avro.generic.GenericData
-
Makes a deep copy of a value given its schema.
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.avro.file.BZip2Codec
-
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.trevni.BZip2Codec
-
- DEFAULT_COMPRESSION - Static variable in class org.apache.avro.file.XZCodec
-
- DEFAULT_COMPRESSION - Static variable in class org.apache.avro.file.ZstandardCodec
-
- DEFAULT_CONNECTION_TIMEOUT_MILLIS - Static variable in class org.apache.avro.ipc.netty.NettyTransceiver
-
If not specified, the default connection timeout will be used (60 sec).
- DEFAULT_DEFLATE_LEVEL - Static variable in class org.apache.avro.file.CodecFactory
-
- DEFAULT_END_ACTION - Static variable in class org.apache.avro.io.parsing.Symbol
-
- DEFAULT_SYNC_INTERVAL - Static variable in class org.apache.avro.file.DataFileConstants
-
- DEFAULT_TCP_NODELAY_VALUE - Static variable in class org.apache.avro.ipc.netty.NettyTransceiver
-
- DEFAULT_USE_BUFFERPOOL - Static variable in class org.apache.avro.file.ZstandardCodec
-
- DEFAULT_XZ_LEVEL - Static variable in class org.apache.avro.file.CodecFactory
-
- DEFAULT_ZSTANDARD_BUFFERPOOL - Static variable in class org.apache.avro.file.CodecFactory
-
- DEFAULT_ZSTANDARD_LEVEL - Static variable in class org.apache.avro.file.CodecFactory
-
- defaultFactory() - Static method in class org.apache.avro.io.DecoderFactory
-
- defaults - Variable in class org.apache.avro.Resolver.RecordAdjust
-
Contains the default values to be used for the last
readerOrder.length-firstDefault fields in rearderOrder.
- defaultStartAction(byte[]) - Static method in class org.apache.avro.io.parsing.Symbol
-
- DefaultStartAction(byte[]) - Constructor for class org.apache.avro.io.parsing.Symbol.DefaultStartAction
-
Deprecated.
- defaultSymbol(String) - Method in class org.apache.avro.SchemaBuilder.EnumBuilder
-
Set the default value of the enum.
- defaultVal() - Method in class org.apache.avro.Schema.Field
-
- defaultValue(Schema.Field) - Method in class org.apache.avro.data.RecordBuilderBase
-
Gets the default value of the given field, if any.
- DEFLATE_CODEC - Static variable in class org.apache.avro.file.DataFileConstants
-
- DEFLATE_LEVEL_KEY - Static variable in class org.apache.avro.mapred.AvroOutputFormat
-
The configuration key for Avro deflate level.
- deflateCodec(int) - Static method in class org.apache.avro.file.CodecFactory
-
Deflate codec, with specific compression.
- DeflateCodec - Class in org.apache.avro.file
-
Implements DEFLATE (RFC1951) compression and decompression.
- DeflateCodec(int) - Constructor for class org.apache.avro.file.DeflateCodec
-
- depth() - Method in class org.apache.avro.io.parsing.Parser
-
Returns the depth of the stack.
- depth() - Method in class org.apache.avro.io.ParsingEncoder
-
- describe(Schema) - Static method in class org.apache.avro.util.SchemaUtil
-
- describe(Object) - Static method in class org.apache.avro.util.SchemaUtil
-
- deserialize(T) - Method in class org.apache.avro.hadoop.io.AvroDeserializer
- directBinaryDecoder(InputStream, BinaryDecoder) - Method in class org.apache.avro.io.DecoderFactory
-
Creates or reinitializes a
BinaryDecoder
with the input stream
provided as the source of data.
- DirectBinaryEncoder - Class in org.apache.avro.io
-
An
Encoder
for Avro's binary encoding that does not buffer output.
- directBinaryEncoder(OutputStream, BinaryEncoder) - Method in class org.apache.avro.io.EncoderFactory
-
Creates or reinitializes a
BinaryEncoder
with the OutputStream
provided as the destination for written data.
- doAction(Symbol, Symbol) - Method in class org.apache.avro.io.JsonDecoder
-
- doAction(Symbol, Symbol) - Method in class org.apache.avro.io.JsonEncoder
-
- doAction(Symbol, Symbol) - Method in interface org.apache.avro.io.parsing.Parser.ActionHandler
-
Handle the action symbol top when the input is sought to be
taken off the stack.
- doAction(Symbol, Symbol) - Method in class org.apache.avro.io.ResolvingDecoder
-
- doAction(Symbol, Symbol) - Method in class org.apache.avro.io.ValidatingDecoder
-
- doAction(Symbol, Symbol) - Method in class org.apache.avro.io.ValidatingEncoder
-
- doc() - Method in class org.apache.avro.Schema.Field
-
Field's documentation within the record, if set.
- doc(String) - Method in class org.apache.avro.SchemaBuilder.NamedBuilder
-
configure this type's optional documentation string
- doCompile(File, File) - Method in class org.apache.avro.compiler.specific.ProtocolTask
-
- doCompile(File, File) - Method in class org.apache.avro.compiler.specific.SchemaTask
-
- doCompile(String, File, File) - Method in class org.apache.avro.mojo.AbstractAvroMojo
-
- doCompile(String, File, File) - Method in class org.apache.avro.mojo.IDLProtocolMojo
-
- doCompile(String, File, File) - Method in class org.apache.avro.mojo.ProtocolMojo
-
- doCompile(String, File, File) - Method in class org.apache.avro.mojo.SchemaMojo
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.stats.StatsServlet
-
- DoNothing(Schema, Schema, GenericData) - Constructor for class org.apache.avro.Resolver.DoNothing
-
- doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.avro.ipc.ResponderServlet
-
- doReadBytes(byte[], int, int) - Method in class org.apache.avro.io.BinaryDecoder
-
Reads length bytes into bytes starting at start.
- doReadItemCount() - Method in class org.apache.avro.io.BinaryDecoder
-
Returns the number of items to follow in the current array or map.
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.ArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.BooleanTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.BytesTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.DoubleTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.FloatTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.IntTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.LongTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.MapTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.SmallLongTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.StringTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericStringTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.generic.GenericWithPromotionTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordWithDefaultTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.RecordWithPromotionTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.ResolvingRecordTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateDecode
-
- doSetupInvocation() - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateDecode
-
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ArrayTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BooleanTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BooleanTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BytesTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.BytesTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.DoubleTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.DoubleTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.ExtendedEnumTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.FloatTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.FloatTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.IntTest.TestStateDecode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.IntTest.TestStateEncode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.LongTest.TestStateDecode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.LongTest.TestStateEncode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.MapTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.MapTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.SmallLongTest.TestStateDecode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.SmallLongTest.TestStateEncode
-
Avro uses Zig-Zag variable length encoding for numeric values.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.StringTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.StringTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.basic.UnchangedUnionTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedFakeTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericNestedTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericStringTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericStringTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithDefaultTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithOutOfOrderTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.generic.GenericWithPromotionTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordWithDefaultTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordWithOutOfOrderTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.RecordWithPromotionTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.ResolvingRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.record.ValidatingRecordTest.TestStateEncode
-
Setup each trial
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectBigRecordTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectDoubleArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectFloatArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectIntArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayBlockedTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLargeFloatArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectLongArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedFloatArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectNestedObjectArrayTest.TestStateEncode
-
Setup the trial data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateDecode
-
Generate test data.
- doSetupTrial() - Method in class org.apache.avro.perf.test.reflect.ReflectRecordTest.TestStateEncode
-
Setup the trial data.
- doSkipBytes(long) - Method in class org.apache.avro.io.BinaryDecoder
-
- DOUBLE - Static variable in class org.apache.avro.io.parsing.Symbol
-
- doubleBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
Build a double type that can set custom properties.
- doubleBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
Build a double type that can set custom properties.
- doubleBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
Build a double type that can set custom properties.
- doubleDefault(double) - Method in class org.apache.avro.SchemaBuilder.DoubleDefault
-
Completes this field with the default value provided
- DoubleTest - Class in org.apache.avro.perf.test.basic
-
- DoubleTest() - Constructor for class org.apache.avro.perf.test.basic.DoubleTest
-
- DoubleTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
-
- DoubleTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
-
- DoubleTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_decode_jmhTest
-
- DoubleTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_encode_jmhTest
-
- DoubleTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType
-
- DoubleTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B1
-
- DoubleTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B2
-
- DoubleTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_jmhType_B3
-
- DoubleTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType
-
- DoubleTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B1
-
- DoubleTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B2
-
- DoubleTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateDecode_jmhType_B3
-
- DoubleTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType
-
- DoubleTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B1
-
- DoubleTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B2
-
- DoubleTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- DoubleTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.DoubleTest_TestStateEncode_jmhType_B3
-
- doubleType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
A plain double type without custom properties.
- doubleType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
A plain double type without custom properties.
- doubleType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
A plain double type without custom properties.
- DoubleWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.DoubleWritableConverter
-
Constructor.
- drain() - Method in class org.apache.avro.io.ResolvingDecoder
-
Consume any more data that has been written by the writer but not needed by
the reader so that the the underlying decoder is in proper shape for the next
record.
- dump(Input, PrintStream, boolean) - Method in class org.apache.avro.tool.TrevniMetadataTool
-
Read a Trevni file and print each row as a JSON object.
- f1 - Variable in class org.apache.avro.perf.test.BasicRecord
-
- f2 - Variable in class org.apache.avro.perf.test.BasicRecord
-
- f2 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f22 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f3 - Variable in class org.apache.avro.perf.test.BasicRecord
-
- f3 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f33 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f4 - Variable in class org.apache.avro.perf.test.BasicRecord
-
- f4 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f44 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f5 - Variable in class org.apache.avro.perf.test.BasicRecord
-
- f5 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f55 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f6 - Variable in class org.apache.avro.perf.test.BasicRecord
-
- f6 - Variable in class org.apache.avro.perf.test.BigRecord
-
- f66 - Variable in class org.apache.avro.perf.test.BigRecord
-
- fail(String) - Method in interface org.apache.avro.mapred.tether.OutputProtocol
-
Called by a failing task to abort.
- FAST_READER_PROP - Static variable in class org.apache.avro.generic.GenericData
-
- FastReaderBuilder - Class in org.apache.avro.io
-
- FastReaderBuilder(GenericData) - Constructor for class org.apache.avro.io.FastReaderBuilder
-
- FastReaderBuilder.ExecutionStep - Interface in org.apache.avro.io
-
- FastReaderBuilder.FieldReader - Interface in org.apache.avro.io
-
- FastReaderBuilder.MapReader - Class in org.apache.avro.io
-
- FastReaderBuilder.RecordReader - Class in org.apache.avro.io
-
- FastReaderBuilder.RecordReader.Stage - Enum in org.apache.avro.io
-
- FastReaderBuilder.ReusingFieldReader - Interface in org.apache.avro.io
-
- Field(Schema.Field, Schema) - Constructor for class org.apache.avro.Schema.Field
-
Constructs a new Field instance with the same name
, doc
,
defaultValue
, and order
as field
has with changing
the schema to the specified one.
- Field(String, Schema) - Constructor for class org.apache.avro.Schema.Field
-
- Field(String, Schema, String) - Constructor for class org.apache.avro.Schema.Field
-
- Field(String, Schema, String, Object) - Constructor for class org.apache.avro.Schema.Field
-
- Field(String, Schema, String, Object, Schema.Field.Order) - Constructor for class org.apache.avro.Schema.Field
-
- FIELD_ACTION - Static variable in class org.apache.avro.io.parsing.Symbol
-
- FIELD_END - Static variable in class org.apache.avro.io.parsing.Symbol
-
- fieldActions - Variable in class org.apache.avro.Resolver.RecordAdjust
-
An action for each field of the writer.
- fieldAdjustAction(int, String, Set<String>) - Static method in class org.apache.avro.io.parsing.Symbol
-
- FieldAdjustAction(int, String, Set<String>) - Constructor for class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
-
Deprecated.
- fieldOrderAction(Schema.Field[]) - Static method in class org.apache.avro.io.parsing.Symbol
-
- FieldOrderAction(Schema.Field[]) - Constructor for class org.apache.avro.io.parsing.Symbol.FieldOrderAction
-
Deprecated.
- fields() - Method in class org.apache.avro.data.RecordBuilderBase
-
- fields - Variable in class org.apache.avro.io.parsing.Symbol.FieldOrderAction
-
- fields() - Method in class org.apache.avro.SchemaBuilder.RecordBuilder
-
- fieldSetFlags() - Method in class org.apache.avro.data.RecordBuilderBase
-
- FileReader<D> - Interface in org.apache.avro.file
-
Interface for reading data from a file.
- findByFingerprint(long) - Method in class org.apache.avro.message.SchemaStore.Cache
-
- findByFingerprint(long) - Method in interface org.apache.avro.message.SchemaStore
-
Retrieves a fingerprint by its AVRO-CRC-64 fingerprint.
- findLabel(String) - Method in class org.apache.avro.io.parsing.Symbol.Alternative
-
- findLabel(String) - Method in class org.apache.avro.io.parsing.Symbol.EnumLabelsAction
-
- findStringClass(Schema) - Method in class org.apache.avro.generic.GenericDatumReader
-
Determines the class to used to represent a string Schema.
- findStringClass(Schema) - Method in class org.apache.avro.specific.SpecificDatumReader
-
- fingerprint(String, byte[]) - Static method in class org.apache.avro.SchemaNormalization
-
Returns a fingerprint of a string of bytes.
- fingerprint64(Schema) - Static method in class org.apache.avro.compiler.specific.SpecificCompiler
-
Utility for use by templates.
- fingerprint64(byte[]) - Static method in class org.apache.avro.SchemaNormalization
-
Returns the 64-bit Rabin Fingerprint (as recommended in the Avro spec) of a
byte string.
- finishInitialization(FastReaderBuilder.ExecutionStep[], Schema, GenericData.InstanceSupplier) - Method in class org.apache.avro.io.FastReaderBuilder.RecordReader
-
- firstDefault - Variable in class org.apache.avro.Resolver.RecordAdjust
-
- firstMatch - Variable in class org.apache.avro.Resolver.ReaderUnion
-
- Fixed(Schema) - Constructor for class org.apache.avro.generic.GenericData.Fixed
-
- Fixed(Schema, byte[]) - Constructor for class org.apache.avro.generic.GenericData.Fixed
-
- Fixed() - Constructor for class org.apache.avro.generic.GenericData.Fixed
-
- FIXED - Static variable in class org.apache.avro.io.parsing.Symbol
-
- fixed(String) - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
Build an Avro fixed type.
- fixed(String) - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
Build an Avro fixed type.
- fixed(String) - Static method in class org.apache.avro.SchemaBuilder
-
Create a builder for an Avro fixed type with the specified name and size.
- fixed(String) - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
Build an Avro fixed type.
- fixedDefault(byte[]) - Method in class org.apache.avro.SchemaBuilder.FixedDefault
-
Completes this field with the default value provided, cannot be null
- fixedDefault(ByteBuffer) - Method in class org.apache.avro.SchemaBuilder.FixedDefault
-
Completes this field with the default value provided, cannot be null
- fixedDefault(String) - Method in class org.apache.avro.SchemaBuilder.FixedDefault
-
Completes this field with the default value provided, cannot be null.
- FixedSize - Annotation Type in org.apache.avro.specific
-
- flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.Alternative
-
- flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol
-
- flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.Repeater
-
- flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.ResolvingAction
-
- flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.Sequence
-
- flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.SkipAction
-
- flatten(Map<Symbol.Sequence, Symbol.Sequence>, Map<Symbol.Sequence, List<Symbol.Fixup>>) - Method in class org.apache.avro.io.parsing.Symbol.UnionAdjustAction
-
- flattenedSize() - Method in class org.apache.avro.io.parsing.Symbol
-
- flattenedSize(Symbol[], int) - Static method in class org.apache.avro.io.parsing.Symbol
-
Returns the amount of space required to flatten the given sub-array of
symbols.
- flattenedSize() - Method in class org.apache.avro.io.parsing.Symbol.Sequence
-
- FLOAT - Static variable in class org.apache.avro.io.parsing.Symbol
-
- floatBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
Build a float type that can set custom properties.
- floatBuilder() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
Build a float type that can set custom properties.
- floatBuilder() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
Build a float type that can set custom properties.
- floatDefault(float) - Method in class org.apache.avro.SchemaBuilder.FloatDefault
-
Completes this field with the default value provided
- FloatTest - Class in org.apache.avro.perf.test.basic
-
- FloatTest() - Constructor for class org.apache.avro.perf.test.basic.FloatTest
-
- FloatTest.TestStateDecode - Class in org.apache.avro.perf.test.basic
-
- FloatTest.TestStateEncode - Class in org.apache.avro.perf.test.basic
-
- FloatTest_decode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_decode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_decode_jmhTest
-
- FloatTest_encode_jmhTest - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_encode_jmhTest() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_encode_jmhTest
-
- FloatTest_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType
-
- FloatTest_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B1
-
- FloatTest_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B2
-
- FloatTest_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_jmhType_B3
-
- FloatTest_TestStateDecode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateDecode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType
-
- FloatTest_TestStateDecode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateDecode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B1
-
- FloatTest_TestStateDecode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateDecode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B2
-
- FloatTest_TestStateDecode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateDecode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateDecode_jmhType_B3
-
- FloatTest_TestStateEncode_jmhType - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateEncode_jmhType() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType
-
- FloatTest_TestStateEncode_jmhType_B1 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateEncode_jmhType_B1() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B1
-
- FloatTest_TestStateEncode_jmhType_B2 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateEncode_jmhType_B2() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B2
-
- FloatTest_TestStateEncode_jmhType_B3 - Class in org.apache.avro.perf.test.basic.jmh_generated
-
- FloatTest_TestStateEncode_jmhType_B3() - Constructor for class org.apache.avro.perf.test.basic.jmh_generated.FloatTest_TestStateEncode_jmhType_B3
-
- floatType() - Method in class org.apache.avro.SchemaBuilder.BaseFieldTypeBuilder
-
A plain float type without custom properties.
- floatType() - Method in class org.apache.avro.SchemaBuilder.BaseTypeBuilder
-
A plain float type without custom properties.
- floatType() - Method in class org.apache.avro.SchemaBuilder.UnionFieldTypeBuilder
-
A plain float type without custom properties.
- FloatWritableConverter() - Constructor for class org.apache.avro.hadoop.io.AvroDatumConverterFactory.FloatWritableConverter
-
Constructor.
- flush() - Method in class org.apache.avro.file.DataFileWriter
-
- flush() - Method in class org.apache.avro.grpc.AvroInputStream.CountingOutputStream
-
- flush() - Method in class org.apache.avro.io.BlockingBinaryEncoder
-
- flush() - Method in class org.apache.avro.io.BufferedBinaryEncoder
-
- flush() - Method in class org.apache.avro.io.DirectBinaryEncoder
-
- flush() - Method in class org.apache.avro.io.JsonEncoder
-
- flush() - Method in class org.apache.avro.io.ValidatingEncoder
-
- flush() - Method in class org.apache.trevni.avro.mapreduce.AvroTrevniRecordWriterBase
-
A Trevni flush will close the current file and prep a new writer
- fname - Variable in class org.apache.avro.io.parsing.Symbol.FieldAdjustAction
-
- FOOTER_BLOCK - Static variable in class org.apache.avro.file.DataFileConstants
-
- forName(String) - Static method in class org.apache.avro.util.ClassUtils
-
Loads a class using the class loader.
- forName(Class<?>, String) - Static method in class org.apache.avro.util.ClassUtils
-
Loads a class using the class loader.
- forName(ClassLoader, String) - Static method in class org.apache.avro.util.ClassUtils
-
Loads a class using the class loader.
- forName(String) - Static method in enum org.apache.trevni.ValueType
-
Return a type given its name.
- fromArray(Collection<?>, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromBoolean(Boolean, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromByteBuffer(ByteBuffer) - Static method in class org.apache.avro.ipc.HandshakeRequest
-
Deserializes a HandshakeRequest from a ByteBuffer.
- fromByteBuffer(ByteBuffer) - Static method in class org.apache.avro.ipc.HandshakeResponse
-
Deserializes a HandshakeResponse from a ByteBuffer.
- fromBytes(ByteBuffer, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromBytes(ByteBuffer, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DecimalConversion
-
- fromCharSequence(CharSequence, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromCharSequence(CharSequence, Schema, LogicalType) - Method in class org.apache.avro.Conversions.UUIDConversion
-
- fromDouble(Double, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromEnumSymbol(GenericEnumSymbol, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromFixed(GenericFixed, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromFixed(GenericFixed, Schema, LogicalType) - Method in class org.apache.avro.Conversions.DecimalConversion
-
- fromFloat(Float, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromHadoopString(String) - Static method in class org.apache.avro.hadoop.file.HadoopCodecFactory
-
Maps a hadoop codec name into a CodecFactory.
- fromInt(Integer, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromInt(Integer, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.DateConversion
-
- fromInt(Integer, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimeMillisConversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMicrosConversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.LocalTimestampMillisConversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimeMicrosConversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampMicrosConversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.data.TimeConversions.TimestampMillisConversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMicrosConversion
-
- fromLong(Long, Schema, LogicalType) - Method in class org.apache.avro.protobuf.ProtoConversions.TimestampMillisConversion
-
- fromMap(Map<?, ?>, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromRecord(IndexedRecord, Schema, LogicalType) - Method in class org.apache.avro.Conversion
-
- fromSchema(Schema) - Static method in class org.apache.avro.LogicalTypes
-
Returns the
LogicalType
from the schema, if one is present.
- fromSchema(Schema) - Method in interface org.apache.avro.LogicalTypes.LogicalTypeFactory
-
- fromSchemaIgnoreInvalid(Schema) - Static method in class org.apache.avro.LogicalTypes
-
- fromString(String) - Static method in class org.apache.avro.file.CodecFactory
-
Maps a codec name into a CodecFactory.
- FromTextTool - Class in org.apache.avro.tool
-
Reads a text file into an Avro data file.
- FromTextTool() - Constructor for class org.apache.avro.tool.FromTextTool
-
- FsInput - Class in org.apache.avro.mapred
-
- FsInput(Path, Configuration) - Constructor for class org.apache.avro.mapred.FsInput
-
Construct given a path and a configuration.
- FsInput(Path, FileSystem) - Constructor for class org.apache.avro.mapred.FsInput
-
Construct given a path and a FileSystem
.
- fSync() - Method in class org.apache.avro.file.DataFileWriter
-
If this writer was instantiated using a File or using an
Syncable instance, this method flushes all buffers for this
writer to disk.