Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.avro Classes and Interfaces - 355 results found.
NameDescriptionTypePackageFramework
AbstractAvroMojoBase for Avro Compiler Mojos.Classorg.apache.avro.mojoAvro
AvroAliasAdds the given name and space as an alias to the schema.Classorg.apache.avro.reflectAvro
AvroAsTextInputFormatAn InputFormat for Avro data files, which converts each datum to string form in the input key.Classorg.apache.avro.mapredAvro
AvroCharSequenceComparatorCompares Avro string data (data with schema string).Classorg.apache.avro.hadoop.utilAvro
AvroCollectorA collector for map and reduce output.Classorg.apache.avro.mapredAvro
AvroDatumConverterConverts a Java object into an Avro datum.Classorg.apache.avro.hadoop.ioAvro
AvroDatumConverterFactoryConstructs converters that turn objects (usually from the output of a MR job) into Avro data that can be serialized.Classorg.apache.avro.hadoop.ioAvro
AvroDatumConverterFactory .AvroWrapperConverterConverts AvroWrappers into their wrapped Avro data.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .BooleanWritableConverterConverts BooleanWritables into Booleans.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .BytesWritableConverterConverts BytesWritables into ByteBuffers.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .ByteWritableConverterConverts ByteWritables into GenericFixed of size 1.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .DoubleWritableConverterConverts DoubleWritables into Doubles.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .FloatWritableConverterConverts FloatWritables into Floats.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .IntWritableConverterConverts IntWritables into Ints.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .LongWritableConverterConverts LongWritables into Longs.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .NullWritableConverterConverts NullWritables into Nulls.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDatumConverterFactory .TextConverterConverts Text into CharSequences.Classorg.apache.avro.hadoop.io.AvroDatumConverterFactoryAvro
AvroDeserializerDeserializes AvroWrapper objects within Hadoop.Classorg.apache.avro.hadoop.ioAvro
AvroEncodeExpert: Fields with this annotation are encoded using the given custom encoder.Classorg.apache.avro.reflectAvro
AvroInputFormatAn InputFormat for Avro data files.Classorg.apache.avro.mapredAvro
AvroJobSetters to configure jobs for Avro data.Classorg.apache.avro.mapredAvro
AvroJobUtility methods for configuring jobs that work with Avro.Classorg.apache.avro.mapreduceAvro
AvroKeyThe wrapper of keys for jobs configured with AvroJob .Classorg.apache.avro.mapredAvro
AvroKeyComparatorThe RawComparator used by jobs configured with Compares AvroKeys output from the map phase for sorting.Classorg.apache.avro.hadoop.ioAvro
AvroKeyComparatorThe RawComparator used by jobs configured with AvroJob.Classorg.apache.avro.mapredAvro
AvroKeyDeserializerDeserializes AvroKey objects within Hadoop.Classorg.apache.avro.hadoop.ioAvro
AvroKeyInputFormatA MapReduce InputFormat that can handle Avro container files.Classorg.apache.avro.mapreduceAvro
AvroKeyOutputFormatFileOutputFormat for writing Avro container files.Classorg.apache.avro.mapreduceAvro
AvroKeyOutputFormat .RecordWriterFactoryA factory for creating record writers.Classorg.apache.avro.mapreduce.AvroKeyOutputFormatAvro
AvroKeyRecordReaderReads records from an input split representing a chunk of an Avro container file.Classorg.apache.avro.mapreduceAvro
AvroKeyRecordWriterWrites Avro records to an Avro container file output stream.Classorg.apache.avro.mapreduceAvro
AvroKeyValueA helper object for working with the Avro generic records that are used to store key/value pairs in an Avro container file.Classorg.apache.avro.hadoop.ioAvro
AvroKeyValue .IteratorA wrapper for iterators over GenericRecords that are known to be KeyValue records.Classorg.apache.avro.hadoop.io.AvroKeyValueAvro
AvroKeyValueInputFormatA MapReduce InputFormat that reads from Avro container files of key/value generic records.Classorg.apache.avro.mapreduceAvro
AvroKeyValueOutputFormatFileOutputFormat for writing Avro container files of key/value pairs.Classorg.apache.avro.mapreduceAvro
AvroKeyValueRecordReaderReads Avro generic records from an Avro container file, where the records contain two fields: 'key' and 'value'.Classorg.apache.avro.mapreduceAvro
AvroKeyValueRecordWriterWrites key/value pairs to an Avro container file.Classorg.apache.avro.mapreduceAvro
AvroMapperA mapper for Avro data.Classorg.apache.avro.mapredAvro
AvroMetaAdds the given key:Value pair as metadata into the schema, at the corresponding node.Classorg.apache.avro.reflectAvro
AvroMultipleInputsThis class supports Avro-MapReduce jobs that have multiple input paths with a different Schema and AvroMapper for each path.Classorg.apache.avro.mapredAvro
AvroMultipleOutputsThe AvroMultipleOutputs class simplifies writing Avro output data to multiple outputsClassorg.apache.avro.mapredAvro
AvroMultipleOutputsThe AvroMultipleOutputs class simplifies writing Avro output data to multiple outputsClassorg.apache.avro.mapreduceAvro
AvroNameSets the avroname for this java field.Classorg.apache.avro.reflectAvro
AvroOutputFormatAn OutputFormat for Avro data files.Classorg.apache.avro.mapredAvro
AvroOutputFormatBaseAbstract base class for output formats that write Avro container files.Classorg.apache.avro.mapreduceAvro
AvroRecordReaderAn RecordReader for Avro data files.Classorg.apache.avro.mapredAvro
AvroRecordReaderBaseAbstract base class for RecordReaders that read Avro container files.Classorg.apache.avro.mapreduceAvro
AvroReducerA reducer for Avro data.Classorg.apache.avro.mapredAvro
AvroRemoteExceptionBase class for exceptions thrown to client by server.Classorg.apache.avroAvro
AvroRuntimeExceptionBase Avro exception.Classorg.apache.avroAvro
AvroSchemaDeclares that a Java type should have a specified Avro schema, overriding the normally inferred schema.Classorg.apache.avro.reflectAvro
AvroSequenceFileA wrapper around a Hadoop SequenceFile that also supports reading and writing Avro data.Classorg.apache.avro.hadoop.ioAvro
AvroSequenceFile .ReaderA reader for SequenceFiles that may contain Avro data.Classorg.apache.avro.hadoop.io.AvroSequenceFileAvro
AvroSequenceFile .Reader .OptionsA helper class to encapsulate the options that can be used to construct a Reader.Classorg.apache.avro.hadoop.io.AvroSequenceFile.ReaderAvro
AvroSequenceFile .WriterA writer for an uncompressed SequenceFile that supports Avro data.Classorg.apache.avro.hadoop.io.AvroSequenceFileAvro
AvroSequenceFile .Writer .OptionsA helper class to encapsulate the options that can be used to construct a Writer.Classorg.apache.avro.hadoop.io.AvroSequenceFile.WriterAvro
AvroSequenceFileInputFormatAn input format for reading from AvroSequenceFiles (sequence files that support Avro data).Classorg.apache.avro.mapreduceAvro
AvroSequenceFileOutputFormatA sequence file output format that knows how to write AvroKeys and AvroValues in addition to Writables.Classorg.apache.avro.mapreduceAvro
AvroSerializationClassorg.apache.avro.hadoop.ioAvro
AvroSerializationThe Serialization used by jobs configured with AvroJob.Classorg.apache.avro.mapredAvro
AvroSerializerSerializes AvroWrapper objects within Hadoop.Classorg.apache.avro.hadoop.ioAvro
AvroTextOutputFormatThe equivalent of TextOutputFormat for writing to Avro Data Files with a bytes schema.Classorg.apache.avro.mapredAvro
AvroTypeExceptionThrown when an illegal type is used.Classorg.apache.avroAvro
AvroUtf8InputFormatAn InputFormat for text files.Classorg.apache.avro.mapredAvro
AvroValueThe wrapper of values for jobs configured with AvroJob .Classorg.apache.avro.mapredAvro
AvroValueDeserializerDeserializes AvroValue objects within Hadoop.Classorg.apache.avro.hadoop.ioAvro
AvroWrapperThe wrapper of data for jobs configured with AvroJob .Classorg.apache.avro.mapredAvro
BinaryDataUtilities for binary-encoded data.Classorg.apache.avro.ioAvro
BinaryDecoderAn Decoder for binary-format data.Classorg.apache.avro.ioAvro
BinaryEncoderAn abstract Encoder for Avro's binary encoding.Classorg.apache.avro.ioAvro
BinaryFragmentToJsonToolConverts an input file from Avro binary into JSON.Classorg.apache.avro.toolAvro
BlockingBinaryEncoderA BinaryEncoder implementation that writes large arrays and maps as a sequence of blocks.Classorg.apache.avro.ioAvro
BufferedBinaryEncoderAn Encoder for Avro's binary encoding.Classorg.apache.avro.ioAvro
ByteBufferInputStreamUtility to present ByteBuffer data as an InputStream.Classorg.apache.avro.utilAvro
ByteBufferOutputStreamUtility to collect data written to an OutputStream in ByteBuffers.Classorg.apache.avro.utilAvro
BZip2CodecClassorg.apache.avro.fileAvro
CallbackInterface for receiving asynchronous callbacks.Interfaceorg.apache.avro.ipcAvro
CallFutureA Future implementation for RPCs.Classorg.apache.avro.ipcAvro
CatToolTool to extract samples from an Avro data file.Classorg.apache.avro.toolAvro
ClassUtilsClassorg.apache.avro.utilAvro
CodecInterface for Avro-supported compression codecs for data files.Classorg.apache.avro.fileAvro
CodecFactoryEncapsulates the ability to specify and configure a compression codec.Classorg.apache.avro.fileAvro
ConcatToolClassorg.apache.avro.toolAvro
ConversionConversion between generic and logical type instances.Classorg.apache.avroAvro
ConversionsClassorg.apache.avroAvro
Conversions .DecimalConversionClassorg.apache.avro.ConversionsAvro
Conversions .UUIDConversionClassorg.apache.avro.ConversionsAvro
CreateRandomFileToolCreates a file filled with randomly-generated instances of a schema.Classorg.apache.avro.toolAvro
CustomEncodingExpert: a custom encoder and decoder that writes an object directly to avro.Classorg.apache.avro.reflectAvro
DataFileConstantsConstants used in data files.Classorg.apache.avro.fileAvro
DataFileGetMetaToolReads a data file to get its metadata.Classorg.apache.avro.toolAvro
DataFileGetSchemaToolReads a data file to get its schema.Classorg.apache.avro.toolAvro
DataFileReaderRandom access to files written with DataFileWriter.Classorg.apache.avro.fileAvro
DataFileReader12Read files written by Avro version 1.Classorg.apache.avro.fileAvro
DataFileReadToolClassorg.apache.avro.toolAvro
DataFileRepairToolClassorg.apache.avro.toolAvro
DataFileStreamStreaming access to files written by DataFileWriter.Classorg.apache.avro.fileAvro
DataFileStream .HeaderA handle that can be used to reopen a DataFile without re-reading the header of the stream.Classorg.apache.avro.file.DataFileStreamAvro
DataFileWriterStores in a file a sequence of data conforming to a schema.Classorg.apache.avro.fileAvro
DataFileWriter .AppendWriteExceptionThrown by DataFileWriter.Classorg.apache.avro.file.DataFileWriterAvro
DataFileWriteToolReads new-line delimited JSON records and writers an Avro data file.Classorg.apache.avro.toolAvro
DatagramServerA datagram-based server implementation.Classorg.apache.avro.ipcAvro
DatagramTransceiverA datagram-based Transceiver implementation.Classorg.apache.avro.ipcAvro
DateAsLongEncodingThis encoder/decoder writes a java.Classorg.apache.avro.reflectAvro
DatumReaderRead data of a schema.Interfaceorg.apache.avro.ioAvro
DatumWriterWrite data of a schema.Interfaceorg.apache.avro.ioAvro
DecoderLow-level support for de-serializing Avro values.Classorg.apache.avro.ioAvro
DecoderFactoryA factory for creating and configuring Decoders.Classorg.apache.avro.ioAvro
DirectBinaryEncoderAn Encoder for Avro's binary encoding that does not buffer output.Classorg.apache.avro.ioAvro
EncoderLow-level support for serializing Avro values.Classorg.apache.avro.ioAvro
EncoderFactoryA factory for creating and configuring Encoder instances.Classorg.apache.avro.ioAvro
ErrorBuilderInterfaceorg.apache.avro.dataAvro
FileReaderInterface for reading data from a file.Interfaceorg.apache.avro.fileAvro
FixedSizeDeclares the size of implementations ofRequired Element SummaryClassorg.apache.avro.specificAvro
FromTextToolReads a text file into an Avro data file.Classorg.apache.avro.toolAvro
FsInputAdapt an FSDataInputStream to SeekableInput.Classorg.apache.avro.mapredAvro
GenericArrayArray that permits reuse of contained elements.Interfaceorg.apache.avro.genericAvro
GenericContainerContains data of other types.Interfaceorg.apache.avro.genericAvro
GenericDataUtilities for generic Java data.Classorg.apache.avro.genericAvro
GenericData .ArrayDefault implementation of an array.Classorg.apache.avro.generic.GenericDataAvro
GenericData .EnumSymbolDefault implementation of GenericEnumSymbol.Classorg.apache.avro.generic.GenericDataAvro
GenericData .FixedDefault implementation of GenericFixed.Classorg.apache.avro.generic.GenericDataAvro
GenericData .RecordDefault implementation of GenericRecord.Classorg.apache.avro.generic.GenericDataAvro
GenericData .StringTypeUsed to specify the Java type for a string schema.Classorg.apache.avro.generic.GenericDataAvro
GenericDatumReaderDatumReader for generic Java objects.Classorg.apache.avro.genericAvro
GenericDatumWriterDatumWriter for generic Java objects.Classorg.apache.avro.genericAvro
GenericEnumSymbolInterfaceorg.apache.avro.genericAvro
GenericFixedInterfaceorg.apache.avro.genericAvro
GenericRecordA generic instance of a record schema.Interfaceorg.apache.avro.genericAvro
GenericRecordBuilderA RecordBuilder for generic records.Classorg.apache.avro.genericAvro
GenericRequestorRequestor implementation for generic Java data.Classorg.apache.avro.ipc.genericAvro
GenericResponderResponder implementation for generic Java data.Classorg.apache.avro.ipc.genericAvro
HadoopCodecFactoryEncapsulates the ability to specify and configure an avro compression codec from a given hadoop codec defined with the configuration parameter:Classorg.apache.avro.hadoop.fileAvro
HandshakeMatchClassorg.apache.avro.ipcAvro
HandshakeRequestClassorg.apache.avro.ipcAvro
HandshakeRequest .BuilderRecordBuilder for HandshakeRequest instances.Classorg.apache.avro.ipc.HandshakeRequestAvro
HandshakeResponseClassorg.apache.avro.ipcAvro
HandshakeResponse .BuilderRecordBuilder for HandshakeResponse instances.Classorg.apache.avro.ipc.HandshakeResponseAvro
HelpMojoDisplay help information on avro-maven-plugin.Classorg.apache.avro.mojoAvro
HttpServerAn HTTP-based RPC Server.Classorg.apache.avro.ipcAvro
HttpTransceiverAn HTTP-based Transceiver implementation.Classorg.apache.avro.ipcAvro
IDLProtocolMojoGenerate Java classes and interfaces from AvroIDL files (.Classorg.apache.avro.mojoAvro
IdlToolClassorg.apache.avro.toolAvro
IdlToSchemataToolClassorg.apache.avro.toolAvro
IndexedRecordA record implementation that permits field access by integer index.Interfaceorg.apache.avro.genericAvro
InduceSchemaToolUtility to induce a schema from a class or a protocol from an interface.Classorg.apache.avro.toolAvro
InputProtocolInterfaceorg.apache.avro.mapred.tetherAvro
InputProtocol .CallbackInterfaceorg.apache.avro.mapred.tether.InputProtocolAvro
IpcIPC utilities, including client and server factories.Classorg.apache.avro.ipcAvro
JsonUtilities for reading and writing arbitrary Json data in Avro format.Classorg.apache.avro.dataAvro
Json .ObjectReaderDatumReader for arbitrary Json data using the object model described in JsonProperties.Classorg.apache.avro.data.JsonAvro
Json .ObjectWriterDatumWriter for arbitrary Json data using the object model described in JsonProperties.Classorg.apache.avro.data.JsonAvro
Json .ReaderDatumReader for arbitrary Json data.Classorg.apache.avro.data.JsonAvro
Json .WriterDatumWriter for arbitrary Json data.Classorg.apache.avro.data.JsonAvro
JsonDecoderA Decoder for Avro's JSON data encoding.Classorg.apache.avro.ioAvro
JsonEncoderAn Encoder for Avro's JSON data encoding.Classorg.apache.avro.ioAvro
JsonGrammarGeneratorClassorg.apache.avro.io.parsingAvro
JsonPropertiesBase class for objects that have JSON-valued properties.Classorg.apache.avroAvro
JsonToBinaryFragmentToolTool to convert JSON data into the binary form.Classorg.apache.avro.toolAvro
LocalTransceiverClassorg.apache.avro.ipcAvro
LogicalTypeLogical types provides an opt-in way to extend Avro's types.Classorg.apache.avroAvro
LogicalTypesClassorg.apache.avroAvro
LogicalTypes .DateClassorg.apache.avro.LogicalTypesAvro
LogicalTypes .DecimalClassorg.apache.avro.LogicalTypesAvro
LogicalTypes .TimeMicrosClassorg.apache.avro.LogicalTypesAvro
LogicalTypes .TimeMillisClassorg.apache.avro.LogicalTypesAvro
LogicalTypes .TimestampMicrosClassorg.apache.avro.LogicalTypesAvro
LogicalTypes .TimestampMillisClassorg.apache.avro.LogicalTypesAvro
MainCommand-line driver.Classorg.apache.avro.toolAvro
MD5Classorg.apache.avro.ipcAvro
NettyServerA Netty-based RPC Server implementation.Classorg.apache.avro.ipcAvro
NettyTransceiverA Netty-based Transceiver implementation.Classorg.apache.avro.ipcAvro
NettyTransceiver .NettyTransceiverThreadFactoryCreates threads with unique names based on a specified name prefix.Classorg.apache.avro.ipc.NettyTransceiverAvro
NettyTransportCodecData structure, encoder and decoder classes for the Netty transport.Classorg.apache.avro.ipcAvro
NettyTransportCodec .NettyDataPackTransport protocol data structure when using Netty.Classorg.apache.avro.ipc.NettyTransportCodecAvro
NettyTransportCodec .NettyFrameDecoderProtocol decoder which converts Netty's ChannelBuffer to NettyDataPack which contains a List needed Classorg.apache.avro.ipc.NettyTransportCodecAvro
NettyTransportCodec .NettyFrameEncoderProtocol encoder which converts NettyDataPack which contains the Responder's output List to ChannelBuffer needed Classorg.apache.avro.ipc.NettyTransportCodecAvro
OutputProtocolInterfaceorg.apache.avro.mapred.tetherAvro
OutputProtocol .CallbackInterfaceorg.apache.avro.mapred.tether.OutputProtocolAvro
PairClassorg.apache.avro.mapredAvro
ParserParser is the class that maintains the stack for parsing.Classorg.apache.avro.io.parsingAvro
Parser .ActionHandlerThe parser knows how to handle the terminal and non-terminal symbols.Interfaceorg.apache.avro.io.parsing.ParserAvro
ParsingDecoderClassorg.apache.avro.ioAvro
ParsingEncoderClassorg.apache.avro.ioAvro
ProtobufDataUtilities for serializing Protobuf data in Avro format.Classorg.apache.avro.protobufAvro
ProtobufDatumReaderClassorg.apache.avro.protobufAvro
ProtobufDatumWriterClassorg.apache.avro.protobufAvro
ProtocolA set of messages forming an application protocol.Classorg.apache.avroAvro
ProtocolMojoGenerate Java classes and interfaces from Avro protocol files (.Classorg.apache.avro.mojoAvro
ProtocolTaskAnt task to generate Java interface and classes for a protocol.Classorg.apache.avro.compiler.specificAvro
RecodecToolTool to alter the codec of an Avro data file.Classorg.apache.avro.toolAvro
RecordBuilderInterfaceorg.apache.avro.dataAvro
RecordBuilderBaseAbstract base class for RecordBuilder implementations.Classorg.apache.avro.dataAvro
ReflectDataUtilities to use existing Java classes and interfaces via reflection.Classorg.apache.avro.reflectAvro
ReflectData .AllowNullReflectData implementation that permits null field values.Classorg.apache.avro.reflect.ReflectDataAvro
ReflectDatumReaderClassorg.apache.avro.reflectAvro
ReflectDatumWriterDatumWriter for existing classes via Java reflection.Classorg.apache.avro.reflectAvro
ReflectRequestorA Requestor for existing interfaces.Classorg.apache.avro.ipc.reflectAvro
ReflectResponderResponder for existing interfaces.Classorg.apache.avro.ipc.reflectAvro
RequestorBase class for the client side of a protocol interaction.Classorg.apache.avro.ipcAvro
ResolvingDecoderDecoder that performs type-resolution between the reader's and When resolving schemas, this class will return the values of fields inClassorg.apache.avro.ioAvro
ResolvingGrammarGeneratorClassorg.apache.avro.io.parsingAvro
ResponderBase class for the server side of a protocol interaction.Classorg.apache.avro.ipcAvro
ResponderServletAn HttpServlet that responds to Avro RPC requests.Classorg.apache.avro.ipcAvro
RPCContextThis class represents the context of an RPC call or RPC handshake.Classorg.apache.avro.ipcAvro
RPCPluginAn instrumentation API for RPC metadata.Classorg.apache.avro.ipcAvro
RpcProtocolToolTool to grab the protocol from a remote running service.Classorg.apache.avro.toolAvro
RpcReceiveToolReceives one RPC call and responds.Classorg.apache.avro.toolAvro
RpcSendToolSends a single RPC message.Classorg.apache.avro.toolAvro
SaslSocketServerA Server that uses javax.Classorg.apache.avro.ipcAvro
SaslSocketTransceiverA Transceiver that uses javax.Classorg.apache.avro.ipcAvro
SchemaAn abstract data type.Classorg.apache.avroAvro
Schema .FieldA field within a record.Classorg.apache.avro.SchemaAvro
Schema .Field .OrderHow values of this field should be ordered when sorting records.Classorg.apache.avro.Schema.FieldAvro
Schema .ParserA parser for JSON-format schemas.Classorg.apache.avro.SchemaAvro
Schema .TypeThe type of a schema.Classorg.apache.avro.SchemaAvro
SchemaBuilder A fluent interface for building Schema instances.Classorg.apache.avroAvro
SchemaBuilder .ArrayBuilderBuilds an Avro Array type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .ArrayDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .BaseFieldTypeBuilderA special Builder for Record fields.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .BaseTypeBuilderA common API for building types within a context.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .BooleanBuilderBuilds an Avro boolean type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .BooleanDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .BytesBuilderBuilds an Avro bytes type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .BytesDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .DoubleBuilderBuilds an Avro double type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .DoubleDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .EnumBuilderBuilds an Avro Enum type with optional properties, namespace, doc, and Set properties with SchemaBuilder.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .EnumDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FieldAssemblerClassorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FieldBuilderBuilds a Field in the context of a SchemaBuilder.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FieldDefaultAbstract base class for field defaults.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FieldTypeBuilderFieldTypeBuilder adds unionOf(), nullable(), and optional() to BaseFieldTypeBuilder.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FixedBuilderBuilds an Avro Fixed type with optional properties, namespace, doc, and Set properties with SchemaBuilder.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FixedDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FloatBuilderBuilds an Avro float type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .FloatDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .GenericDefaultClassorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .IntBuilderBuilds an Avro int type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .IntDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .LongBuilderBuilds an Avro long type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .LongDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .MapBuilderBuilds an Avro Map type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .MapDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .NamedBuilderAn abstract type that provides builder methods for configuring the name, doc, and aliases of all Avro types that have names (fields, Fixed, Record,Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .NamespacedBuilderAn abstract type that provides builder methods for configuring the namespace for all Avro types that have namespaces (Fixed, Record, andClassorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .NullBuilderBuilds an Avro null type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .NullDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .PropBuilderAn abstract builder for all Avro types.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .RecordBuilderClassorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .RecordDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .StringBldrBuilds an Avro string type with optional properties.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .StringDefaultChoose whether to use a default value for the field or not.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .TypeBuilderA Builder for creating any Avro schema type.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .UnionAccumulatorAccumulates all of the types in a union.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilder .UnionFieldTypeBuilderBuilder for a union field.Classorg.apache.avro.SchemaBuilderAvro
SchemaBuilderExceptionThrown for errors building schemas.Classorg.apache.avroAvro
SchemaCompatibilityEvaluate the compatibility between a reader schema and a writer schema.Classorg.apache.avroAvro
SchemaCompatibility .SchemaCompatibilityTypeIdentifies the type of a schema compatibility result.Classorg.apache.avro.SchemaCompatibilityAvro
SchemaCompatibility .SchemaPairCompatibilityProvides information about the compatibility of a single reader and writer schema pair.Classorg.apache.avro.SchemaCompatibilityAvro
SchemaMojoGenerate Java classes from Avro schema files (.Classorg.apache.avro.mojoAvro
SchemaNormalizationCollection of static methods for generating the cannonical form of schemas (see toParsingForm(org.Classorg.apache.avroAvro
SchemaParseExceptionThrown for errors parsing schemas and protocols.Classorg.apache.avroAvro
SchemaTaskAnt task to generate Java interface and classes for a protocol.Classorg.apache.avro.compiler.specificAvro
SchemaValidationExceptionThrown when SchemaValidator fails to validate a schema.Classorg.apache.avroAvro
SchemaValidationStrategyAn interface for validating the compatibility of a single schema against What makes one schema compatible with another is not defined by the contract.Interfaceorg.apache.avroAvro
SchemaValidator A SchemaValidator has one method, which validates that a Schema is compatible with the other schemas provided.Interfaceorg.apache.avroAvro
SchemaValidatorBuilder A Builder for creating SchemaValidators.Classorg.apache.avroAvro
SeekableByteArrayInputA SeekableInput backed with data in a byte array.Classorg.apache.avro.fileAvro
SeekableFileInputA FileInputStream that implements SeekableInput.Classorg.apache.avro.fileAvro
SeekableInputAn InputStream that supports seek and tell.Interfaceorg.apache.avro.fileAvro
SequenceFileInputFormatAn InputFormat for sequence files.Classorg.apache.avro.mapredAvro
SequenceFileReaderA FileReader for sequence files.Classorg.apache.avro.mapredAvro
SequenceFileRecordReaderA RecordReader for sequence files.Classorg.apache.avro.mapredAvro
ServerA server listening on a port.Interfaceorg.apache.avro.ipcAvro
SkipParserA parser that capable of skipping as well read and write.Classorg.apache.avro.io.parsingAvro
SkipParser .SkipHandlerThe clients implement this interface to skip symbols and actions.Interfaceorg.apache.avro.io.parsing.SkipParserAvro
SocketServerA socket-based server implementation.Classorg.apache.avro.ipcAvro
SocketTransceiverA socket-based Transceiver implementation.Classorg.apache.avro.ipcAvro
SortedKeyValueFileA SortedKeyValueFile is an indexed Avro container file of KeyValue records The SortedKeyValueFile is a directory with two files, named 'data' andClassorg.apache.avro.hadoop.fileAvro
SortedKeyValueFile .ReaderReads a SortedKeyValueFile by loading the key index into memory.Classorg.apache.avro.hadoop.file.SortedKeyValueFileAvro
SortedKeyValueFile .Reader .OptionsA class to encapsulate the options of a Reader.Classorg.apache.avro.hadoop.file.SortedKeyValueFile.ReaderAvro
SortedKeyValueFile .WriterWrites a SortedKeyValueFile.Classorg.apache.avro.hadoop.file.SortedKeyValueFileAvro
SortedKeyValueFile .Writer .OptionsA class to encapsulate the various options of a SortedKeyValueFile.Classorg.apache.avro.hadoop.file.SortedKeyValueFile.WriterAvro
SpecificCompilerGenerate specific Java interfaces and classes for protocols and schemas.Classorg.apache.avro.compiler.specificAvro
SpecificCompiler .FieldVisibilityClassorg.apache.avro.compiler.specific.SpecificCompilerAvro
SpecificCompiler .Slf4jLogChuteClassorg.apache.avro.compiler.specific.SpecificCompilerAvro
SpecificCompilerToolClassorg.apache.avro.toolAvro
SpecificDataUtilities for generated Java classes and interfaces.Classorg.apache.avro.specificAvro
SpecificDatumReaderDatumReader for generated Java classes.Classorg.apache.avro.specificAvro
SpecificDatumWriterDatumWriter for generated Java classes.Classorg.apache.avro.specificAvro
SpecificErrorBuilderBaseAbstract base class for specific ErrorBuilder implementations.Classorg.apache.avro.specificAvro
SpecificExceptionBaseBase class for specific exceptions.Classorg.apache.avro.specificAvro
SpecificFixedBase class for generated fixed-sized data classes.Classorg.apache.avro.specificAvro
SpecificRecordInterfaceorg.apache.avro.specificAvro
SpecificRecordBaseBase class for generated record classes.Classorg.apache.avro.specificAvro
SpecificRecordBuilderBaseAbstract base class for specific RecordBuilder implementations.Classorg.apache.avro.specificAvro
SpecificRequestorRequestor for generated interfaces.Classorg.apache.avro.ipc.specificAvro
SpecificResponderResponder for generated interfaces.Classorg.apache.avro.ipc.specificAvro
StaticServletVery simple servlet class capable of serving static files.Classorg.apache.avro.ipc.statsAvro
StatsPluginCollects count and latency statistics about RPC calls.Classorg.apache.avro.ipc.statsAvro
StatsServerClassorg.apache.avro.ipc.statsAvro
StatsServletExposes information provided by a StatsPlugin as This class follows the same synchronization conventionsClassorg.apache.avro.ipc.statsAvro
SymbolClassorg.apache.avro.io.parsingAvro
Symbol .AlternativeClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .DefaultStartActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .EnumAdjustActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .EnumLabelsActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .ErrorActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .FieldAdjustActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .FieldOrderActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .ImplicitActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .IntCheckActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .Kindnon-terminal to represent the unionnon-terminal action symbol which is explicitly consumedClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .RepeaterClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .ResolvingActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .RootClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .SequenceClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .SkipActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .UnionAdjustActionClassorg.apache.avro.io.parsing.SymbolAvro
Symbol .WriterUnionActionClassorg.apache.avro.io.parsing.SymbolAvro
SyncableInterfaceorg.apache.avro.fileAvro
SyncableInterfaceorg.apache.avro.mapreduceAvro
SyncableFileOutputStreamAn implementation of Syncable which writes to a file.Classorg.apache.avro.fileAvro
TaskTypeClassorg.apache.avro.mapred.tetherAvro
TetherJobConstructs and submits tether jobs.Classorg.apache.avro.mapred.tetherAvro
TetherToolClassorg.apache.avro.toolAvro
ThriftDataUtilities for serializing Thrift data in Avro format.Classorg.apache.avro.thriftAvro
ThriftDatumReaderClassorg.apache.avro.thriftAvro
ThriftDatumWriterClassorg.apache.avro.thriftAvro
TimeConversionsClassorg.apache.avro.dataAvro
TimeConversions .DateConversionClassorg.apache.avro.data.TimeConversionsAvro
TimeConversions .LossyTimeMicrosConversionClassorg.apache.avro.data.TimeConversionsAvro
TimeConversions .LossyTimestampMicrosConversionClassorg.apache.avro.data.TimeConversionsAvro
TimeConversions .TimeConversionClassorg.apache.avro.data.TimeConversionsAvro
TimeConversions .TimeMicrosConversionClassorg.apache.avro.data.TimeConversionsAvro
TimeConversions .TimestampConversionClassorg.apache.avro.data.TimeConversionsAvro
TimeConversions .TimestampMicrosConversionClassorg.apache.avro.data.TimeConversionsAvro
ToolCommand-line avro-tools utilities should implement this interface for delegation by Main.Interfaceorg.apache.avro.toolAvro
ToTextToolReads an avro data file into a plain text file.Classorg.apache.avro.toolAvro
ToTrevniToolReads an Avro data file and writes a Trevni file.Classorg.apache.avro.toolAvro
TransceiverBase transport class used by Requestor.Classorg.apache.avro.ipcAvro
TrevniCreateRandomToolClassorg.apache.avro.toolAvro
TrevniMetadataToolTool to print Trevni file metadata as JSON.Classorg.apache.avro.toolAvro
TrevniToJsonToolTool to read Trevni files and print them as JSON.Classorg.apache.avro.toolAvro
UnionDeclares that a Java type should be represented by an Avro union schema.Classorg.apache.avro.reflectAvro
UnresolvedUnionExceptionThrown when the expected contents of a union cannot be resolved.Classorg.apache.avroAvro
Utf8A Utf8 string.Classorg.apache.avro.utilAvro
ValidateAll A SchemaValidator for validating the provided schema against all schemas in the Iterable in validate(Schema, Iterable).Classorg.apache.avroAvro
ValidateLatest A SchemaValidator for validating the provided schema against the first Schema in the iterable in validate(Schema, Iterable).Classorg.apache.avroAvro
ValidatingDecoderAn implementation of Decoder that ensures that the sequence of operations conforms to a schema.Classorg.apache.avro.ioAvro
ValidatingEncoderAn implementation of Encoder that wraps another Encoder and ensures that the sequence of operations conforms to the provided schema.Classorg.apache.avro.ioAvro
ValidatingGrammarGeneratorThe class that generates validating grammar.Classorg.apache.avro.io.parsingAvro
WeakIdentityHashMap Useful for caches that need to key off of a == comparison instead of a .Classorg.apache.avro.utilAvro
XZCodecClassorg.apache.avro.fileAvro