Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- ACID_STATS - Static variable in class org.apache.orc.impl.OrcAcidUtils
- AcidStats - Class in org.apache.orc.impl
-
Statistics about the ACID operations in an ORC file
- AcidStats() - Constructor for class org.apache.orc.impl.AcidStats
- AcidStats(String) - Constructor for class org.apache.orc.impl.AcidStats
- add() - Method in class org.apache.orc.impl.StringRedBlackTree
-
Add the new key to the tree.
- add(byte) - Method in class org.apache.orc.impl.DynamicByteArray
- add(byte[]) - Method in class org.apache.orc.util.BloomFilter
- add(byte[], int, int) - Method in interface org.apache.orc.impl.Dictionary
- add(byte[], int, int) - Method in class org.apache.orc.impl.DynamicByteArray
-
Copy a slice of a byte array into our buffer.
- add(byte[], int, int) - Method in class org.apache.orc.impl.StringHashTableDictionary
- add(byte[], int, int) - Method in class org.apache.orc.impl.StringRedBlackTree
- add(int) - Method in class org.apache.orc.impl.DynamicIntArray
- add(String) - Method in class org.apache.orc.impl.StringRedBlackTree
- add(Text) - Method in class org.apache.orc.impl.StringHashTableDictionary
- add(Text) - Method in class org.apache.orc.impl.StringRedBlackTree
- add(BufferChunk) - Method in class org.apache.orc.impl.BufferChunkList
- addBytes(byte[], int, int) - Method in class org.apache.orc.util.BloomFilter
- addChild(TypeDescription) - Method in class org.apache.orc.TypeDescription
-
Add a child to a type.
- addColumn(TypeDescription) - Method in class org.apache.orc.impl.MaskDescriptionImpl
- addDouble(double) - Method in class org.apache.orc.util.BloomFilter
- addedRow(int) - Method in class org.apache.orc.impl.MemoryManagerImpl
- addedRow(int) - Method in interface org.apache.orc.MemoryManager
-
Deprecated.
- addEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- addField(String, TypeDescription) - Method in class org.apache.orc.TypeDescription
-
Add a field to a struct type as it is built.
- addKey(String, int, EncryptionAlgorithm, byte[]) - Method in class org.apache.orc.InMemoryKeystore
-
Function that takes care of adding a new key.
A new key can be added only if: This is a new key and no prior key version exist. If the key exists (has versions), then the new version to be added should be greater than the version that already exists. - addKey(String, EncryptionAlgorithm, byte[]) - Method in class org.apache.orc.InMemoryKeystore
-
Function that takes care of adding a new key.
A new key can be added only if: This is a new key and no prior key version exist. If the key exists (has versions), then the new version to be added should be greater than the version that already exists. - addLong(long) - Method in class org.apache.orc.util.BloomFilter
- addPosition(long) - Method in interface org.apache.orc.impl.PositionRecorder
- addRoot(WriterEncryptionVariant) - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- addRowBatch(VectorizedRowBatch) - Method in class org.apache.orc.impl.WriterImpl
- addRowBatch(VectorizedRowBatch) - Method in interface org.apache.orc.Writer
-
Add a row batch to the ORC file.
- addString(String) - Method in class org.apache.orc.util.BloomFilter
- addString(String) - Method in class org.apache.orc.util.BloomFilterUtf8
- addStripeStatistics(StripeStatistics[]) - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- addStripeStatistics(StripeStatistics[]) - Method in class org.apache.orc.impl.writer.ListTreeWriter
- addStripeStatistics(StripeStatistics[]) - Method in class org.apache.orc.impl.writer.MapTreeWriter
- addStripeStatistics(StripeStatistics[]) - Method in class org.apache.orc.impl.writer.StructTreeWriter
- addStripeStatistics(StripeStatistics[]) - Method in interface org.apache.orc.impl.writer.TreeWriter
-
During a stripe append, we need to handle the stripe statistics.
- addStripeStatistics(StripeStatistics[]) - Method in class org.apache.orc.impl.writer.TreeWriterBase
- addStripeStatistics(StripeStatistics[]) - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- addUnionChild(TypeDescription) - Method in class org.apache.orc.TypeDescription
-
Add a child to a union type.
- addUserMetadata(String, ByteBuffer) - Method in class org.apache.orc.impl.WriterImpl
- addUserMetadata(String, ByteBuffer) - Method in interface org.apache.orc.Writer
-
Add arbitrary meta-data to the ORC file.
- addWriter(Path, long, MemoryManager.Callback) - Method in class org.apache.orc.impl.MemoryManagerImpl
-
Add a new writer's memory allocation to the pool.
- addWriter(Path, long, MemoryManager.Callback) - Method in interface org.apache.orc.MemoryManager
-
Add a new writer's memory allocation to the pool.
- AircompressorCodec - Class in org.apache.orc.impl
- ALL - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
- allow(ColumnVector, int) - Method in class org.apache.orc.impl.filter.LeafFilter
- ALLOW_PLUGIN_FILTER - Enum constant in enum class org.apache.orc.OrcConf
- ALLOW_SARG_TO_FILTER - Enum constant in enum class org.apache.orc.OrcConf
- allowPluginFilters() - Method in class org.apache.orc.Reader.Options
- allowPluginFilters(boolean) - Method in class org.apache.orc.Reader.Options
- allowSARGToFilter(boolean) - Method in class org.apache.orc.Reader.Options
-
Set allowSARGToFilter.
- AndFilter - Class in org.apache.orc.impl.filter
- AndFilter(VectorFilter[]) - Constructor for class org.apache.orc.impl.filter.AndFilter
- annotateEncryption(String, String) - Method in class org.apache.orc.TypeDescription
-
Annotate a schema with the encryption keys and masks.
- append(Path, int, Progressable) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- appendRawStripe(ByteBuffer, OrcProto.StripeInformation.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- appendRawStripe(ByteBuffer, OrcProto.StripeInformation.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Appends raw stripe data (e.g.
- appendStripe(byte[], int, int, StripeInformation, OrcProto.StripeStatistics) - Method in class org.apache.orc.impl.WriterImpl
- appendStripe(byte[], int, int, StripeInformation, OrcProto.StripeStatistics) - Method in interface org.apache.orc.Writer
-
Fast stripe append to ORC file.
- appendStripe(byte[], int, int, StripeInformation, StripeStatistics[]) - Method in class org.apache.orc.impl.WriterImpl
- appendStripe(byte[], int, int, StripeInformation, StripeStatistics[]) - Method in interface org.apache.orc.Writer
-
Fast stripe append to ORC file.
- appendUserMetadata(List<OrcProto.UserMetadataItem>) - Method in class org.apache.orc.impl.WriterImpl
- appendUserMetadata(List<OrcProto.UserMetadataItem>) - Method in interface org.apache.orc.Writer
-
Deprecated.use
Writer.addUserMetadata(String, ByteBuffer)
instead - assertBufferSizeValid(int) - Static method in class org.apache.orc.impl.OutStream
-
Throws exception if the bufferSize argument equals or exceeds 2^(3*8 - 1).
- assignStringGroupVectorEntry(BytesColumnVector, int, TypeDescription, byte[]) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- assignStringGroupVectorEntry(BytesColumnVector, int, TypeDescription, byte[], int, int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- atTime(LocalTime) - Method in class org.threeten.extra.chrono.HybridDate
- available() - Method in class org.apache.orc.impl.InStream.CompressedStream
- available() - Method in class org.apache.orc.impl.InStream.UncompressedStream
B
- BASE_DELTA_RATIO - Enum constant in enum class org.apache.orc.OrcConf
- base_timestamp - Variable in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- BASE_TIMESTAMP_STRING - Static variable in class org.apache.orc.impl.writer.TimestampTreeWriter
- BatchFilter - Interface in org.apache.orc.filter
-
Defines a batch filter that can operate on a
VectorizedRowBatch
and filter rows by using the selected vector to determine the eligible rows. - BatchReader - Class in org.apache.orc.impl.reader.tree
-
The top level interface that the reader uses to read the columns from the ORC file.
- BatchReader(TypeReader) - Constructor for class org.apache.orc.impl.reader.tree.BatchReader
- BINARY - Enum constant in enum class org.apache.orc.CompressionCodec.DataKind
- BINARY - Enum constant in enum class org.apache.orc.TypeDescription.Category
- BinaryColumnStatistics - Interface in org.apache.orc
-
Statistics for binary columns.
- BinaryTreeReader(int, InStream, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- BinaryTreeWriter - Class in org.apache.orc.impl.writer
- BinaryTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.BinaryTreeWriter
- BitFieldReader - Class in org.apache.orc.impl
- BitFieldReader(InStream) - Constructor for class org.apache.orc.impl.BitFieldReader
- BitFieldWriter - Class in org.apache.orc.impl
- BitFieldWriter(PositionedOutputStream, int) - Constructor for class org.apache.orc.impl.BitFieldWriter
- BitSet(long) - Constructor for class org.apache.orc.util.BloomFilter.BitSet
- BitSet(long[]) - Constructor for class org.apache.orc.util.BloomFilter.BitSet
-
Deserialize long array as bit set.
- bitSize() - Method in class org.apache.orc.util.BloomFilter.BitSet
-
Number of bits
- BLOCK_PADDING - Enum constant in enum class org.apache.orc.OrcConf
- BLOCK_PADDING_TOLERANCE - Enum constant in enum class org.apache.orc.OrcConf
- BLOCK_SIZE - Enum constant in enum class org.apache.orc.OrcConf
- blockPadding(boolean) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Sets whether the HDFS blocks are padded to prevent stripes from straddling blocks.
- blockSize(long) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the file system block size for the file.
- BLOOM_FILTER_COLUMNS - Enum constant in enum class org.apache.orc.OrcConf
- BLOOM_FILTER_FPP - Enum constant in enum class org.apache.orc.OrcConf
- BLOOM_FILTER_WRITE_VERSION - Enum constant in enum class org.apache.orc.OrcConf
- bloomFilter - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- BloomFilter - Class in org.apache.orc.util
-
BloomFilter is a probabilistic data structure for set membership check.
- BloomFilter(long) - Constructor for class org.apache.orc.util.BloomFilter
- BloomFilter(long[], int) - Constructor for class org.apache.orc.util.BloomFilter
-
A constructor to support rebuilding the BloomFilter from a serialized representation.
- BloomFilter(long, double) - Constructor for class org.apache.orc.util.BloomFilter
- BloomFilter.BitSet - Class in org.apache.orc.util
-
Bare metal bit set implementation.
- bloomFilterColumns(String) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Comma separated values of column names for which bloom filter is to be created.
- bloomFilterEntry - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- bloomFilterFpp(double) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Specify the false positive probability for bloom filter.
- BloomFilterIO - Class in org.apache.orc.util
- BloomFilterIO.Encoding - Enum Class in org.apache.orc.util
- bloomFilterUtf8 - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- BloomFilterUtf8 - Class in org.apache.orc.util
-
This class represents the fix from ORC-101 where we fixed the bloom filter from using the JVM's default character set to always using UTF-8.
- BloomFilterUtf8(long[], int) - Constructor for class org.apache.orc.util.BloomFilterUtf8
- BloomFilterUtf8(long, double) - Constructor for class org.apache.orc.util.BloomFilterUtf8
- bloomFilterVersion(OrcFile.BloomFilterVersion) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Deprecated.
- BOOLEAN - Enum constant in enum class org.apache.orc.TypeDescription.Category
- BooleanColumnStatistics - Interface in org.apache.orc
-
Statistics for boolean columns.
- BooleanTreeReader(int, InStream, InStream, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.BooleanTreeReader
- BooleanTreeWriter - Class in org.apache.orc.impl.writer
- BooleanTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.BooleanTreeWriter
- BROTLI - Enum constant in enum class org.apache.orc.CompressionKind
- BrotliCodec - Class in org.apache.orc.impl
- BrotliCodec() - Constructor for class org.apache.orc.impl.BrotliCodec
- BUFFER_SIZE - Enum constant in enum class org.apache.orc.OrcConf
- BufferChunk - Class in org.apache.orc.impl
-
The sections of stripe that we have read.
- BufferChunk(long, int) - Constructor for class org.apache.orc.impl.BufferChunk
- BufferChunk(ByteBuffer, long) - Constructor for class org.apache.orc.impl.BufferChunk
- BufferChunkList - Class in org.apache.orc.impl
-
Builds a list of buffer chunks
- BufferChunkList() - Constructor for class org.apache.orc.impl.BufferChunkList
- bufferSize - Variable in class org.apache.orc.impl.ReaderImpl
- bufferSize(int) - Method in class org.apache.orc.impl.writer.StreamOptions
- bufferSize(int) - Method in class org.apache.orc.OrcFile.WriterOptions
-
The size of the memory buffers used for compressing and storing the stripe in memory.
- build() - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- build(DataMaskDescription, TypeDescription, DataMask.MaskOverrides) - Static method in class org.apache.orc.DataMask.Factory
-
Build a new DataMask instance.
- build(DataMaskDescription, TypeDescription, DataMask.MaskOverrides) - Method in interface org.apache.orc.DataMask.Provider
-
Build a mask with the given parameters.
- build(DataMaskDescription, TypeDescription, DataMask.MaskOverrides) - Method in class org.apache.orc.impl.mask.MaskProvider
- build(TypeDescription, DataMask.MaskOverrides) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildBinaryMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildBinaryMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildBinaryMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- buildBooleanMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildBooleanMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildBooleanMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- buildChildren(List<TypeDescription>, DataMask.MaskOverrides) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildDateMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildDateMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildDateMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- buildDecimalMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildDecimalMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildDecimalMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- buildDoubleMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildDoubleMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildDoubleMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- builder() - Static method in class org.apache.orc.impl.DataReaderProperties
- buildIndex() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Should be building the row index.
- buildIndex(boolean) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Sets whether build the index.
- buildLongMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildLongMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildLongMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- buildMaskDescription(String) - Static method in class org.apache.orc.impl.ParserUtils
- buildStringMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildStringMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildStringMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- buildStructMask(TypeDescription, DataMask.MaskOverrides) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildTimestampMask(TypeDescription) - Method in class org.apache.orc.impl.mask.MaskFactory
- buildTimestampMask(TypeDescription) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
- buildTimestampMask(TypeDescription) - Method in class org.apache.orc.impl.mask.SHA256MaskFactory
- byName(String) - Static method in enum class org.apache.orc.OrcFile.Version
- BYTE - Enum constant in enum class org.apache.orc.TypeDescription.Category
- byteArray() - Static method in class org.apache.orc.impl.IOUtils
-
Returns a new byte array of size
IOUtils.DEFAULT_BUFFER_SIZE
. - byteArray(int) - Static method in class org.apache.orc.impl.IOUtils
-
Returns a new byte array of the given size.
- ByteBufferAllocatorPool() - Constructor for class org.apache.orc.impl.RecordReaderUtils.ByteBufferAllocatorPool
- bytes - Variable in class org.apache.orc.impl.InStream
- BytesColumnVectorUtil() - Constructor for class org.apache.orc.impl.TreeReaderFactory.BytesColumnVectorUtil
- bytesColVector - Variable in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromAnyIntegerTreeReader
- bytesToLongBE(InStream, int) - Method in class org.apache.orc.impl.SerializationUtils
-
Read n bytes in big endian order and convert to long
- bytesVectorToString(BytesColumnVector, int) - Static method in class org.apache.orc.impl.SerializationUtils
-
Convert a bytes vector element into a String.
- ByteTreeReader(int, InStream, InStream, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.ByteTreeReader
- ByteTreeWriter - Class in org.apache.orc.impl.writer
- ByteTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.ByteTreeWriter
C
- callback(OrcFile.WriterCallback) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Add a listener for when the stripe and file are about to be closed.
- canConvert(TypeDescription, TypeDescription) - Static method in class org.apache.orc.impl.ConvertTreeReaderFactory
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.BitFieldWriter
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.InStream
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.InStream.CompressedStream
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.InStream.EncryptedStream
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.InStream.UncompressedStream
- changeIv(Consumer<byte[]>) - Method in interface org.apache.orc.impl.IntegerWriter
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.OutStream
-
Change the current Initialization Vector (IV) for the encryption.
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.PositionedOutputStream
-
Change the current Initialization Vector (IV) for the encryption.
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.RunLengthByteWriter
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.RunLengthIntegerWriter
- changeIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.RunLengthIntegerWriterV2
- CHAR - Enum constant in enum class org.apache.orc.TypeDescription.Category
- charLength(byte[], int, int) - Static method in class org.apache.orc.impl.Utf8Utils
- CharTreeReader(int, int, InStream, InStream, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.CharTreeReader
- CharTreeWriter - Class in org.apache.orc.impl.writer
-
Under the covers, char is written to ORC the same way as string.
- checkAcidSchema(TypeDescription) - Static method in class org.apache.orc.impl.SchemaEvolution
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- checkEncoding(OrcProto.ColumnEncoding) - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- checkMemory(double) - Method in class org.apache.orc.impl.WriterImpl
- checkMemory(double) - Method in interface org.apache.orc.MemoryManager.Callback
-
The scale factor for the stripe size has changed and thus the writer should adjust their desired size appropriately.
- checkMemory(long, MemoryManager.Callback) - Method in class org.apache.orc.impl.MemoryManagerImpl
- checkMemory(long, MemoryManager.Callback) - Method in interface org.apache.orc.MemoryManager
-
As part of adding rows, the writer calls this method to determine if the scale factor has changed.
- checkOrcVersion(Path, OrcProto.PostScript) - Static method in class org.apache.orc.impl.ReaderImpl
-
Check to see if this ORC file is from a future version and if so, warn the user that we may not be able to read all of the column encodings.
- clear() - Method in class org.apache.orc.impl.BufferChunkList
- clear() - Method in interface org.apache.orc.impl.Dictionary
- clear() - Method in class org.apache.orc.impl.DynamicByteArray
-
Clear the array to its original pristine state.
- clear() - Method in class org.apache.orc.impl.DynamicIntArray
- clear() - Static method in class org.apache.orc.impl.OrcCodecPool
-
Clear the codec pool.
- clear() - Method in class org.apache.orc.impl.RecordReaderUtils.ByteBufferAllocatorPool
- clear() - Method in class org.apache.orc.impl.StringHashTableDictionary
- clear() - Method in class org.apache.orc.impl.StringRedBlackTree
-
Reset the table to empty.
- clear() - Method in class org.apache.orc.util.BloomFilter.BitSet
-
Clear the bit set.
- clearCounter(byte[]) - Static method in class org.apache.orc.impl.CryptoUtils
-
Clear the counter part of the IV.
- clearEncodings() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- clearFileStatistics() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- clearStreams() - Method in class org.apache.orc.impl.reader.StripePlanner
-
Release all of the buffers for the current stripe.
- clone() - Method in interface org.apache.orc.DataReader
-
Clone the entire state of the DataReader with the assumption that the clone will be closed at a different time.
- clone() - Method in class org.apache.orc.impl.InStream.StreamOptions
- clone() - Method in class org.apache.orc.OrcFile.WriterOptions
- clone() - Method in class org.apache.orc.Reader.Options
- clone() - Method in class org.apache.orc.TypeDescription
- close() - Method in interface org.apache.orc.CompressionCodec
-
Return the codec to the pool.
- close() - Method in interface org.apache.orc.DataReader
- close() - Method in class org.apache.orc.impl.AircompressorCodec
- close() - Method in class org.apache.orc.impl.BrotliCodec
- close() - Method in class org.apache.orc.impl.InStream
- close() - Method in class org.apache.orc.impl.InStream.CompressedStream
- close() - Method in class org.apache.orc.impl.InStream.EncryptedStream
- close() - Method in class org.apache.orc.impl.InStream.UncompressedStream
- close() - Method in class org.apache.orc.impl.PhysicalFsWriter
- close() - Method in class org.apache.orc.impl.ReaderImpl
- close() - Method in class org.apache.orc.impl.RecordReaderImpl
- close() - Method in class org.apache.orc.impl.WriterImpl
- close() - Method in class org.apache.orc.impl.ZlibCodec
- close() - Method in class org.apache.orc.impl.ZstdCodec
- close() - Method in interface org.apache.orc.PhysicalWriter
-
Closes the writer.
- close() - Method in interface org.apache.orc.RecordReader
-
Release the resources associated with the given reader.
- close() - Method in interface org.apache.orc.Writer
-
Flush all of the buffers and close the file.
- CollectionColumnStatistics - Interface in org.apache.orc
-
Statistics for all of collections such as Map and List.
- column - Variable in class org.apache.orc.impl.reader.StripePlanner.StreamInformation
- columnId - Variable in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- ColumnStatistics - Interface in org.apache.orc
-
Statistics that are available for all types of columns.
- ColumnStatisticsImpl - Class in org.apache.orc.impl
- ColumnStatisticsImpl.BinaryStatisticsImpl - Class in org.apache.orc.impl
- ColumnStatisticsImpl.StringStatisticsImpl - Class in org.apache.orc.impl
- compare(byte[], int, int, int, int) - Method in class org.apache.orc.impl.DynamicByteArray
-
Byte compare a set of bytes against the bytes in this dynamic array.
- compareTo(EncryptionKey) - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- compareTo(EncryptionKey) - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- compareTo(EncryptionVariant) - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- compareTo(EncryptionVariant) - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- compareTo(MaskDescriptionImpl) - Method in class org.apache.orc.impl.MaskDescriptionImpl
- compareTo(StreamName) - Method in class org.apache.orc.impl.StreamName
- compareTo(TypeDescription) - Method in class org.apache.orc.TypeDescription
- compareValue(int) - Method in class org.apache.orc.impl.StringRedBlackTree
- compress(ByteBuffer, ByteBuffer, ByteBuffer, CompressionCodec.Options) - Method in interface org.apache.orc.CompressionCodec
-
Compress the in buffer to the out buffer.
- compress(ByteBuffer, ByteBuffer, ByteBuffer, CompressionCodec.Options) - Method in class org.apache.orc.impl.AircompressorCodec
- compress(ByteBuffer, ByteBuffer, ByteBuffer, CompressionCodec.Options) - Method in class org.apache.orc.impl.BrotliCodec
- compress(ByteBuffer, ByteBuffer, ByteBuffer, CompressionCodec.Options) - Method in class org.apache.orc.impl.ZlibCodec
- compress(ByteBuffer, ByteBuffer, ByteBuffer, CompressionCodec.Options) - Method in class org.apache.orc.impl.ZstdCodec
-
Compresses an input ByteBuffer into an output ByteBuffer using Zstandard compression.
- compress(CompressionKind) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Sets the generic compression that is used to compress the data.
- COMPRESS - Enum constant in enum class org.apache.orc.OrcConf
- compressed - Variable in class org.apache.orc.impl.InStream.CompressedStream
- compressedBuffer - Variable in class org.apache.orc.impl.OutStream
-
Lazily initialized: Won't allocate byte buffer until invocation of init()
- CompressedStream(Object, long, long, InStream.StreamOptions) - Constructor for class org.apache.orc.impl.InStream.CompressedStream
-
Create the stream without resetting the input stream.
- CompressedStream(Object, DiskRangeList, long, long, InStream.StreamOptions) - Constructor for class org.apache.orc.impl.InStream.CompressedStream
-
Create the stream and initialize the input for the stream.
- COMPRESSION - Enum constant in enum class org.apache.orc.OrcFile.CompressionStrategy
- COMPRESSION - Enum constant in enum class org.apache.orc.OrcFile.EncodingStrategy
- COMPRESSION_STRATEGY - Enum constant in enum class org.apache.orc.OrcConf
- COMPRESSION_ZSTD_LEVEL - Enum constant in enum class org.apache.orc.OrcConf
- COMPRESSION_ZSTD_WINDOWLOG - Enum constant in enum class org.apache.orc.OrcConf
- CompressionCodec - Interface in org.apache.orc
-
The API for compression codecs for ORC.
- CompressionCodec.DataKind - Enum Class in org.apache.orc
- CompressionCodec.Options - Interface in org.apache.orc
- CompressionCodec.SpeedModifier - Enum Class in org.apache.orc
- compressionKind - Variable in class org.apache.orc.impl.ReaderImpl
- CompressionKind - Enum Class in org.apache.orc
-
An enumeration that lists the generic compression algorithms that can be applied to ORC files.
- conf - Variable in class org.apache.orc.impl.ReaderImpl
- contains(TypeReader.ReaderCategory) - Method in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
- context - Variable in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- context - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- convertBetweenTimezones(TimeZone, TimeZone, long) - Static method in class org.apache.orc.impl.SerializationUtils
-
Find the relative offset when moving between timezones at a particular point in time.
- convertDate(int, boolean, boolean) - Static method in class org.apache.orc.impl.DateUtils
- convertDateToHybrid(int) - Static method in class org.apache.orc.impl.DateUtils
-
Convert an epoch day from the proleptic Gregorian calendar to the hybrid Julian/Gregorian.
- convertDateToProleptic(int) - Static method in class org.apache.orc.impl.DateUtils
-
Convert an epoch day from the hybrid Julian/Gregorian calendar to the proleptic Gregorian.
- convertFromUtc(TimeZone, double) - Static method in class org.apache.orc.impl.SerializationUtils
-
Convert a UTC time to a local timezone
- convertFromUtc(TimeZone, long) - Static method in class org.apache.orc.impl.SerializationUtils
- convertProtoStripesToStripes(List<OrcProto.StripeInformation>) - Static method in class org.apache.orc.OrcUtils
- convertStringGroupVectorElement(BytesColumnVector, int, TypeDescription) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- convertTime(long, boolean, boolean, boolean) - Static method in class org.apache.orc.impl.DateUtils
- convertTimeToHybrid(long, boolean) - Static method in class org.apache.orc.impl.DateUtils
-
Convert epoch millis from the proleptic Gregorian calendar to the hybrid Julian/Gregorian.
- convertTimeToProleptic(long, boolean) - Static method in class org.apache.orc.impl.DateUtils
-
Convert epoch millis from the hybrid Julian/Gregorian calendar to the proleptic Gregorian.
- convertToProlepticGregorian(boolean) - Method in class org.apache.orc.OrcFile.ReaderOptions
-
Should the reader convert dates and times to the proleptic Gregorian calendar?
- convertToUtc(TimeZone, long) - Static method in class org.apache.orc.impl.SerializationUtils
- ConvertTreeReaderFactory - Class in org.apache.orc.impl
-
Convert ORC tree readers.
- ConvertTreeReaderFactory() - Constructor for class org.apache.orc.impl.ConvertTreeReaderFactory
- ConvertTreeReaderFactory.AnyIntegerFromAnyIntegerTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.AnyIntegerFromDecimalTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.AnyIntegerFromDoubleTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.AnyIntegerFromStringGroupTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.AnyIntegerFromTimestampTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.ConvertTreeReader - Class in org.apache.orc.impl
-
Override methods like checkEncoding to pass-thru to the convert TreeReader.
- ConvertTreeReaderFactory.DateFromStringGroupTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DateFromTimestampTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DecimalFromAnyIntegerTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DecimalFromDecimalTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DecimalFromDoubleTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DecimalFromStringGroupTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DecimalFromTimestampTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DoubleFromAnyIntegerTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DoubleFromDecimalTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DoubleFromStringGroupTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.DoubleFromTimestampTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.FloatFromDoubleTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromAnyIntegerTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromBinaryTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromBooleanTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromDateTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromDecimalTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromDoubleTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromStringGroupTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.StringGroupFromTimestampTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.TimestampFromAnyIntegerTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.TimestampFromDateTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.TimestampFromDecimalTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.TimestampFromDoubleTreeReader - Class in org.apache.orc.impl
- ConvertTreeReaderFactory.TimestampFromStringGroupTreeReader - Class in org.apache.orc.impl
- convertTypeFromProtobuf(List<OrcProto.Type>, int) - Static method in class org.apache.orc.OrcUtils
-
Translate the given rootColumn from the list of types to a TypeDescription.
- convertVector(ColumnVector, ColumnVector, int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- copy() - Method in interface org.apache.orc.CompressionCodec.Options
-
Make a copy before making changes.
- count - Variable in class org.apache.orc.impl.ColumnStatisticsImpl
- countNonNullRowsInRange(boolean[], int, int) - Static method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- countNonNulls(long) - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- create(Object, DiskRangeList, long, long) - Static method in class org.apache.orc.impl.InStream
-
Create an input stream from a list of disk ranges with data.
- create(Object, DiskRangeList, long, long, InStream.StreamOptions) - Static method in class org.apache.orc.impl.InStream
-
Create an input stream from a list of disk ranges with data.
- create(String, Configuration, Random) - Method in class org.apache.orc.impl.CryptoUtils.HadoopKeyProviderFactory
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- create(TypeDescription) - Static method in class org.apache.orc.impl.ColumnStatisticsImpl
- create(TypeDescription, boolean) - Static method in class org.apache.orc.impl.ColumnStatisticsImpl
- create(TypeDescription, DataMask.MaskOverrides) - Method in class org.apache.orc.impl.MaskDescriptionImpl
- create(TypeDescription, WriterEncryptionVariant, WriterContext) - Static method in class org.apache.orc.impl.writer.TreeWriter.Factory
-
Create a new tree writer for the given types and insert encryption if required.
- createBatchFilter(Reader.Options, TypeDescription, boolean, OrcFile.Version, boolean, String, Configuration) - Static method in class org.apache.orc.impl.filter.FilterFactory
-
Create a BatchFilter.
- createBinary() - Static method in class org.apache.orc.TypeDescription
- createBloomFilter - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- createBoolean() - Static method in class org.apache.orc.TypeDescription
- createByte() - Static method in class org.apache.orc.TypeDescription
- createChar() - Static method in class org.apache.orc.TypeDescription
- createCodec(CompressionKind) - Static method in class org.apache.orc.impl.WriterImpl
- createCodedInputStream(InStream) - Static method in class org.apache.orc.impl.InStream
-
Creates coded input stream (used for protobuf message parsing) with higher message size limit.
- createColumn(TypeDescription, TypeDescription.RowBatchVersion, int) - Static method in class org.apache.orc.impl.TypeUtils
- createConvertTreeReader(TypeDescription, TreeReaderFactory.Context) - Static method in class org.apache.orc.impl.ConvertTreeReaderFactory
-
(Rules from Hive's PrimitiveObjectInspectorUtils conversion) To BOOLEAN, BYTE, SHORT, INT, LONG: Convert from (BOOLEAN, BYTE, SHORT, INT, LONG) with down cast if necessary.
- createDataStream(StreamName) - Method in class org.apache.orc.impl.PhysicalFsWriter
- createDataStream(StreamName) - Method in interface org.apache.orc.PhysicalWriter
-
Create an OutputReceiver for the given name.
- createDate() - Static method in class org.apache.orc.TypeDescription
- createDecimal() - Static method in class org.apache.orc.TypeDescription
- createDefaultDataReader(DataReaderProperties) - Static method in class org.apache.orc.impl.RecordReaderUtils
- createDouble() - Static method in class org.apache.orc.TypeDescription
- createEventSchema(TypeDescription) - Static method in class org.apache.orc.impl.SchemaEvolution
- createFloat() - Static method in class org.apache.orc.TypeDescription
- createIndexStream(StreamName) - Method in class org.apache.orc.impl.PhysicalFsWriter
- createInt() - Static method in class org.apache.orc.TypeDescription
- createIntegerReader(OrcProto.ColumnEncoding.Kind, InStream, boolean, TreeReaderFactory.Context) - Static method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- createLeafVectorFilter(PredicateLeaf, Set<String>, TypeDescription, boolean, OrcFile.Version, boolean) - Static method in class org.apache.orc.impl.filter.leaf.LeafFilterFactory
- createList(TypeDescription) - Static method in class org.apache.orc.TypeDescription
- createLocalKey(HadoopShims.KeyMetadata) - Method in class org.apache.orc.InMemoryKeystore
-
Create a local key for the given key version.
- createLong() - Static method in class org.apache.orc.TypeDescription
- createMap(TypeDescription, TypeDescription) - Static method in class org.apache.orc.TypeDescription
- createReader(Path, OrcFile.ReaderOptions) - Static method in class org.apache.orc.OrcFile
- createRootReader(TypeDescription, TreeReaderFactory.Context) - Static method in class org.apache.orc.impl.TreeReaderFactory
- createRowBatch() - Method in class org.apache.orc.TypeDescription
-
Create a VectorizedRowBatch with the original ColumnVector types
- createRowBatch(int) - Method in class org.apache.orc.TypeDescription
-
Create a VectorizedRowBatch with the original ColumnVector types
- createRowBatch(TypeDescription.RowBatchVersion, int) - Method in class org.apache.orc.TypeDescription
- createRowBatchV2() - Method in class org.apache.orc.TypeDescription
-
Create a VectorizedRowBatch that uses Decimal64ColumnVector for short (p ≤ 18) decimals.
- createRowIndexEntry() - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- createRowIndexEntry() - Method in class org.apache.orc.impl.writer.ListTreeWriter
- createRowIndexEntry() - Method in class org.apache.orc.impl.writer.MapTreeWriter
- createRowIndexEntry() - Method in class org.apache.orc.impl.writer.StringBaseTreeWriter
-
This method doesn't call the super method, because unlike most of the other TreeWriters, this one can't record the position in the streams until the stripe is being flushed.
- createRowIndexEntry() - Method in class org.apache.orc.impl.writer.StructTreeWriter
- createRowIndexEntry() - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Create a row index entry at the current point in the stripe.
- createRowIndexEntry() - Method in class org.apache.orc.impl.writer.TreeWriterBase
-
Create a row index entry with the previous location and the current index statistics.
- createRowIndexEntry() - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- createSArgFilter(ExpressionTree, Set<String>, List<PredicateLeaf>, TypeDescription, boolean, OrcFile.Version) - Static method in class org.apache.orc.impl.filter.FilterFactory
- createShort() - Static method in class org.apache.orc.TypeDescription
- createStream(StreamName) - Method in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
- createStream(StreamName) - Method in interface org.apache.orc.impl.writer.WriterContext
-
Create a stream to store part of a column.
- createString() - Static method in class org.apache.orc.TypeDescription
- createStruct() - Static method in class org.apache.orc.TypeDescription
- createTimestamp() - Static method in class org.apache.orc.TypeDescription
- createTimestampInstant() - Static method in class org.apache.orc.TypeDescription
- createTreeReader(TypeDescription, TreeReaderFactory.Context) - Static method in class org.apache.orc.impl.TreeReaderFactory
- createUnion() - Static method in class org.apache.orc.TypeDescription
- createVarchar() - Static method in class org.apache.orc.TypeDescription
- createWriter(Path, OrcFile.WriterOptions) - Static method in class org.apache.orc.OrcFile
-
Create an ORC file writer.
- CryptoUtils - Class in org.apache.orc.impl
-
This class has routines to work with encryption within ORC files.
- CryptoUtils() - Constructor for class org.apache.orc.impl.CryptoUtils
- CryptoUtils.HadoopKeyProviderFactory - Class in org.apache.orc.impl
- cs - Variable in class org.apache.orc.StripeStatistics
- CuckooSetBytes - Class in org.apache.orc.util
-
A high-performance set implementation used to support fast set membership testing, using Cuckoo hashing.
- CuckooSetBytes(int) - Constructor for class org.apache.orc.util.CuckooSetBytes
-
Allocate a new set to hold expectedSize values.
- CUDF - Enum constant in enum class org.apache.orc.OrcFile.WriterImplementation
- CUDF_ORIGINAL - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- current - Variable in class org.apache.orc.impl.ParserUtils.TypeFinder
- CURRENT - Static variable in enum class org.apache.orc.OrcFile.Version
- CURRENT - Static variable in enum class org.apache.orc.util.BloomFilterIO.Encoding
- CURRENT_WRITER - Static variable in class org.apache.orc.OrcFile
-
The WriterVersion for this version of the software.
- currentCompressedStart - Variable in class org.apache.orc.impl.InStream.CompressedStream
- currentOffset - Variable in class org.apache.orc.impl.InStream.UncompressedStream
- currentRange - Variable in class org.apache.orc.impl.InStream.CompressedStream
- currentRange - Variable in class org.apache.orc.impl.InStream.UncompressedStream
- CUTOVER - Static variable in class org.threeten.extra.chrono.HybridChronology
-
The cutover date, October 15, 1582.
D
- data - Variable in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- DATA - Enum constant in enum class org.apache.orc.impl.StreamName.Area
- DATA_MASK - Enum constant in enum class org.apache.orc.OrcConf
- DataMask - Interface in org.apache.orc
-
The API for masking data during column encryption for ORC.
- DataMask.Factory - Class in org.apache.orc
-
To create a DataMask, the users should come through this API.
- DataMask.MaskOverrides - Interface in org.apache.orc
-
An interface to provide override data masks for sub-columns.
- DataMask.Provider - Interface in org.apache.orc
-
Providers can provide one or more kinds of data masks.
- DataMask.Standard - Enum Class in org.apache.orc
-
The standard DataMasks can be created using this short cut.
- DataMaskDescription - Interface in org.apache.orc
-
Information about the DataMask used to mask the unencrypted data.
- dataReader(DataReader) - Method in class org.apache.orc.Reader.Options
-
Set dataReader.
- DataReader - Interface in org.apache.orc
-
An abstract data reader that IO formats can use to read bytes from underlying storage.
- DataReaderProperties - Class in org.apache.orc.impl
- DataReaderProperties.Builder - Class in org.apache.orc.impl
- date(int, int, int) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a local date in British Cutover calendar system from the proleptic-year, month-of-year and day-of-month fields.
- date(Era, int, int, int) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a local date in British Cutover calendar system from the era, year-of-era, month-of-year and day-of-month fields.
- date(TemporalAccessor) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a British Cutover local date from another date-time object.
- DATE - Enum constant in enum class org.apache.orc.TypeDescription.Category
- DateColumnStatistics - Interface in org.apache.orc
-
Statistics for DATE columns.
- dateEpochDay(long) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a local date in the British Cutover calendar system from the epoch-day.
- dateNow() - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains the current British Cutover local date from the system clock in the default time-zone.
- dateNow(Clock) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains the current British Cutover local date from the specified clock.
- dateNow(ZoneId) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains the current British Cutover local date from the system clock in the specified time-zone.
- DateTreeReader(int, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- DateTreeWriter - Class in org.apache.orc.impl.writer
- DateTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.DateTreeWriter
- DateUtils - Class in org.apache.orc.impl
-
Conversion utilities from the hybrid Julian/Gregorian calendar to/from the proleptic Gregorian.
- dateYearDay(int, int) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a local date in British Cutover calendar system from the proleptic-year and day-of-year fields.
- dateYearDay(Era, int, int) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a local date in British Cutover calendar system from the era, year-of-era and day-of-year fields.
- DECIMAL - Enum constant in enum class org.apache.orc.TypeDescription.Category
- Decimal64TreeReader(int, InStream, InStream, OrcProto.ColumnEncoding, int, int, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- Decimal64TreeWriter - Class in org.apache.orc.impl.writer
-
Writer for short decimals in ORCv2.
- Decimal64TreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.Decimal64TreeWriter
- DecimalColumnStatistics - Interface in org.apache.orc
-
Statistics for decimal columns.
- DecimalIdentity - Class in org.apache.orc.impl.mask
-
An identity data mask for decimal types.
- DecimalIdentity() - Constructor for class org.apache.orc.impl.mask.DecimalIdentity
- DecimalTreeReader(int, InStream, InStream, InStream, OrcProto.ColumnEncoding, int, int, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- DecimalTreeWriter - Class in org.apache.orc.impl.writer
- DecimalTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.DecimalTreeWriter
- decodeBitWidth(int) - Static method in class org.apache.orc.impl.SerializationUtils
-
Decodes the ordinal fixed bit value to actual fixed bit width value
- decompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.orc.CompressionCodec
-
Decompress the in buffer to the out buffer.
- decompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.AircompressorCodec
- decompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.BrotliCodec
- decompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.SnappyCodec
- decompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.ZlibCodec
- decompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.ZstdCodec
- decrypted - Variable in class org.apache.orc.impl.InStream.UncompressedStream
- decryptLocalKey(HadoopShims.KeyMetadata, byte[]) - Method in class org.apache.orc.InMemoryKeystore
-
Create a local key for the given key version and initialization vector.
- DEFAULT - Enum constant in enum class org.apache.orc.CompressionCodec.SpeedModifier
- DEFAULT_BUFFER_SIZE - Static variable in class org.apache.orc.impl.IOUtils
- DEFAULT_COMPRESSION_BLOCK_SIZE - Static variable in class org.apache.orc.impl.ReaderImpl
- DEFAULT_FPP - Static variable in class org.apache.orc.util.BloomFilter
- delete(Path, boolean) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- deletes - Variable in class org.apache.orc.impl.AcidStats
- DELTA - Enum constant in enum class org.apache.orc.impl.RunLengthIntegerWriterV2.EncodingType
- DELTA_SIDE_FILE_SUFFIX - Static variable in class org.apache.orc.impl.OrcAcidUtils
- deserialize(OrcProto.Stream.Kind, OrcProto.ColumnEncoding, OrcFile.WriterVersion, TypeDescription.Category, OrcProto.BloomFilter) - Static method in class org.apache.orc.util.BloomFilterIO
-
Deserialize a bloom filter from the ORC file.
- deserialize(TypeDescription, OrcProto.ColumnStatistics) - Static method in class org.apache.orc.impl.ColumnStatisticsImpl
- deserialize(TypeDescription, OrcProto.ColumnStatistics, boolean, boolean) - Static method in class org.apache.orc.impl.ColumnStatisticsImpl
- deserializeStats(TypeDescription, List<OrcProto.ColumnStatistics>) - Method in class org.apache.orc.impl.ReaderImpl
- destroy() - Method in interface org.apache.orc.CompressionCodec
-
Closes the codec, releasing the resources.
- destroy() - Method in class org.apache.orc.impl.AircompressorCodec
- destroy() - Method in class org.apache.orc.impl.BrotliCodec
- destroy() - Method in class org.apache.orc.impl.SnappyCodec
- destroy() - Method in class org.apache.orc.impl.ZlibCodec
- destroy() - Method in class org.apache.orc.impl.ZstdCodec
- dictionary - Variable in class org.apache.orc.impl.writer.StringBaseTreeWriter
- Dictionary - Interface in org.apache.orc.impl
-
Interface to define the dictionary used for encoding value in columns of specific types like string, char, varchar, etc.
- DICTIONARY_IMPL - Enum constant in enum class org.apache.orc.OrcConf
- DICTIONARY_KEY_SIZE_THRESHOLD - Enum constant in enum class org.apache.orc.OrcConf
- Dictionary.IMPL - Enum Class in org.apache.orc.impl
- Dictionary.Visitor - Interface in org.apache.orc.impl
-
The interface for visitors.
- Dictionary.VisitorContext - Interface in org.apache.orc.impl
-
The information about each node.
- DictionaryUtils - Class in org.apache.orc.impl
- DIRECT - Enum constant in enum class org.apache.orc.impl.RunLengthIntegerWriterV2.EncodingType
- DIRECT_ENCODING_COLUMNS - Enum constant in enum class org.apache.orc.OrcConf
- directDecompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.BrotliCodec
- directDecompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.orc.impl.DirectDecompressionCodec
- directDecompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.SnappyCodec
- directDecompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.ZlibCodec
- directDecompress(ByteBuffer, ByteBuffer) - Method in class org.apache.orc.impl.ZstdCodec
- DirectDecompressionCodec - Interface in org.apache.orc.impl
- directEncodingColumns(String) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the comma-separated list of columns that should be direct encoded.
- directStreamOutput - Variable in class org.apache.orc.impl.writer.StringBaseTreeWriter
- DOUBLE - Enum constant in enum class org.apache.orc.TypeDescription.Category
- doubleCanFitInLong(double) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- DoubleColumnStatistics - Interface in org.apache.orc
-
Statistics for float and double columns.
- DoubleIdentity - Class in org.apache.orc.impl.mask
-
An identity data mask for floating point types.
- DoubleIdentity() - Constructor for class org.apache.orc.impl.mask.DoubleIdentity
- DoubleTreeReader(int, InStream, InStream, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.DoubleTreeReader
- DoubleTreeWriter - Class in org.apache.orc.impl.writer
- DoubleTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.DoubleTreeWriter
- downCastAnyInteger(LongColumnVector, int, long, TypeDescription) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- downCastAnyInteger(LongColumnVector, int, TypeDescription) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- DynamicByteArray - Class in org.apache.orc.impl
-
A class that is a growable array of bytes.
- DynamicByteArray() - Constructor for class org.apache.orc.impl.DynamicByteArray
- DynamicByteArray(int, int) - Constructor for class org.apache.orc.impl.DynamicByteArray
- DynamicIntArray - Class in org.apache.orc.impl
-
Dynamic int array that uses primitive types and chunks to avoid copying large number of integers when it resizes.
- DynamicIntArray() - Constructor for class org.apache.orc.impl.DynamicIntArray
- DynamicIntArray(int) - Constructor for class org.apache.orc.impl.DynamicIntArray
E
- EIGHT - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- EIGHTEEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- elementReader - Variable in class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- ELEVEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- EMPTY_BYTE_ARRAY - Static variable in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromBinaryTreeReader
- EMPTY_COLUMN_STATISTICS - Static variable in class org.apache.orc.impl.RecordReaderImpl
- ENABLE_INDEXES - Enum constant in enum class org.apache.orc.OrcConf
- encodeBitWidth(int) - Method in class org.apache.orc.impl.SerializationUtils
-
Finds the closest available fixed bit width match and returns its encoded value (ordinal).
- encodeTranslatedSargColumn(int, Integer) - Static method in class org.apache.orc.impl.RecordReaderImpl
- ENCODING_STRATEGY - Enum constant in enum class org.apache.orc.OrcConf
- encodingStrategy(OrcFile.EncodingStrategy) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Sets the encoding strategy that is used to encode the data.
- encrypt(String) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Encrypt a set of columns with a key.
- ENCRYPT_ATTRIBUTE - Static variable in class org.apache.orc.TypeDescription
- EncryptedStream(Object, DiskRangeList, long, long, InStream.StreamOptions) - Constructor for class org.apache.orc.impl.InStream.EncryptedStream
- encryption - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- ENCRYPTION - Enum constant in enum class org.apache.orc.OrcConf
- EncryptionKey - Interface in org.apache.orc
-
Information about a key used for column encryption in an ORC file.
- EncryptionTreeWriter - Class in org.apache.orc.impl.writer
-
TreeWriter that handles column encryption.
- EncryptionVariant - Interface in org.apache.orc
-
Information about a column encryption variant.
- ENFORCE_COMPRESSION_BUFFER_SIZE - Enum constant in enum class org.apache.orc.OrcConf
- enforceBufferSize() - Method in class org.apache.orc.OrcFile.WriterOptions
-
Enforce writer to use requested buffer size instead of estimating buffer size based on stripe size and number of columns.
- ensureOrcFooter(ByteBuffer, int) - Static method in class org.apache.orc.impl.ReaderImpl
-
Deprecated.
- ensureOrcFooter(FSDataInputStream, Path, int, ByteBuffer) - Static method in class org.apache.orc.impl.ReaderImpl
-
Ensure this is an ORC file to prevent users from trying to read text files or RC files as ORC files.
- equals(Object) - Method in class org.apache.orc.impl.BufferChunk
- equals(Object) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- equals(Object) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- equals(Object) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- equals(Object) - Method in class org.apache.orc.impl.MaskDescriptionImpl
- equals(Object) - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- equals(Object) - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- equals(Object) - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- equals(Object) - Method in class org.apache.orc.impl.StreamName
- equals(Object) - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- equals(Object) - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- equals(Object) - Method in class org.apache.orc.TypeDescription
- equals(Object) - Method in class org.apache.orc.util.BloomFilter.BitSet
- equals(Object) - Method in class org.apache.orc.util.BloomFilter
- equals(Object) - Method in class org.threeten.extra.chrono.HybridDate
- equals(Object, boolean) - Method in class org.apache.orc.TypeDescription
-
Determines whether the two object are equal.
- equalsInternal(byte[], int, int, int, DynamicIntArray, DynamicByteArray) - Static method in class org.apache.orc.impl.DictionaryUtils
-
Compare a UTF8 string from the byteArray using the offset in index-array.
- eraOf(int) - Method in class org.threeten.extra.chrono.HybridChronology
- eras() - Method in class org.threeten.extra.chrono.HybridChronology
- estimateMemory() - Method in class org.apache.orc.impl.BitFieldWriter
- estimateMemory() - Method in interface org.apache.orc.impl.IntegerWriter
-
Estimate the amount of memory being used.
- estimateMemory() - Method in class org.apache.orc.impl.RunLengthByteWriter
- estimateMemory() - Method in class org.apache.orc.impl.RunLengthIntegerWriter
- estimateMemory() - Method in class org.apache.orc.impl.RunLengthIntegerWriterV2
- estimateMemory() - Method in class org.apache.orc.impl.writer.BinaryTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.BooleanTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.ByteTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.DateTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.Decimal64TreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.DecimalTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.DoubleTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.FloatTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.IntegerTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.ListTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.MapTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.StringBaseTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.StructTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.writer.TimestampTreeWriter
- estimateMemory() - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Estimate the memory currently used to buffer the stripe.
- estimateMemory() - Method in class org.apache.orc.impl.writer.TreeWriterBase
-
Estimate how much memory the writer is consuming excluding the streams.
- estimateMemory() - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- estimateMemory() - Method in class org.apache.orc.impl.WriterImpl
- estimateMemory() - Method in interface org.apache.orc.Writer
-
Estimate the memory currently used by the writer to buffer the stripe.
- estimateRgEndOffset(boolean, int, boolean, long, long) - Static method in class org.apache.orc.impl.RecordReaderUtils
- evaluatePredicate(ColumnStatistics, PredicateLeaf, BloomFilter) - Static method in class org.apache.orc.impl.RecordReaderImpl
-
Evaluate a predicate with respect to the statistics from the column that is referenced in the predicate.
- evaluatePredicate(ColumnStatistics, PredicateLeaf, BloomFilter, boolean) - Static method in class org.apache.orc.impl.RecordReaderImpl
-
Evaluate a predicate with respect to the statistics from the column that is referenced in the predicate.
- extractFileTail(ByteBuffer) - Static method in class org.apache.orc.impl.ReaderImpl
-
Deprecated.Use
ReaderImpl.extractFileTail(FileSystem, Path, long)
instead. This is for backward compatibility. - extractFileTail(ByteBuffer, long, long) - Static method in class org.apache.orc.impl.ReaderImpl
-
Deprecated.Use
ReaderImpl.extractFileTail(FileSystem, Path, long)
instead. This is for backward compatibility. - extractFileTail(FileSystem, Path, long) - Method in class org.apache.orc.impl.ReaderImpl
- extractMetadata(ByteBuffer, int, int, InStream.StreamOptions) - Static method in class org.apache.orc.impl.ReaderImpl
F
- Factory() - Constructor for class org.apache.orc.DataMask.Factory
- Factory() - Constructor for class org.apache.orc.impl.writer.TreeWriter.Factory
- FAILURE - Enum constant in enum class org.apache.orc.impl.reader.ReaderEncryptionKey.State
- FAST - Enum constant in enum class org.apache.orc.CompressionCodec.SpeedModifier
- FASTEST - Enum constant in enum class org.apache.orc.CompressionCodec.SpeedModifier
- fields - Variable in class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- fields - Variable in class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- FIFTEEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- FIFTYSIX - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- file - Variable in class org.apache.orc.impl.ReaderImpl
- fileFormat(OrcFile.Version) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- FileFormatException - Exception in org.apache.orc
-
Thrown when an invalid file format is encountered.
- FileFormatException(String) - Constructor for exception org.apache.orc.FileFormatException
- fileMetadata(FileMetadata) - Method in class org.apache.orc.OrcFile.ReaderOptions
-
Deprecated.Use
OrcFile.ReaderOptions.orcTail(OrcTail)
instead. - FileMetadata - Interface in org.apache.orc
-
Deprecated.Use
OrcTail
instead - fileStatistics - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- fileStats - Variable in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
- filesystem(FileSystem) - Method in class org.apache.orc.OrcFile.ReaderOptions
- fileSystem(FileSystem) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Provide the filesystem for the path, if the client has it available.
- fileUsedProlepticGregorian() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- fileUsedProlepticGregorian() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- filter(OrcFilterContext, Selected, Selected) - Method in class org.apache.orc.impl.filter.AndFilter
- filter(OrcFilterContext, Selected, Selected) - Method in class org.apache.orc.impl.filter.IsNotNullFilter
- filter(OrcFilterContext, Selected, Selected) - Method in class org.apache.orc.impl.filter.IsNullFilter
- filter(OrcFilterContext, Selected, Selected) - Method in class org.apache.orc.impl.filter.LeafFilter
- filter(OrcFilterContext, Selected, Selected) - Method in class org.apache.orc.impl.filter.OrFilter
- filter(OrcFilterContext, Selected, Selected) - Method in interface org.apache.orc.impl.filter.VectorFilter
-
Filter the vectorized row batch that is wrapped into the FilterContext.
- FILTER_CHILD - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReaderCategory
- FILTER_PARENT - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReaderCategory
- FilterFactory - Class in org.apache.orc.impl.filter
- FilterFactory() - Constructor for class org.apache.orc.impl.filter.FilterFactory
- FilterFactory.UnSupportedSArgException - Exception in org.apache.orc.impl.filter
- filters - Variable in class org.apache.orc.impl.filter.AndFilter
- filters - Variable in class org.apache.orc.impl.filter.OrFilter
- finalizeStripe(OrcProto.StripeFooter.Builder, OrcProto.StripeInformation.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- finalizeStripe(OrcProto.StripeFooter.Builder, OrcProto.StripeInformation.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Flushes the data in all the streams, spills them to disk, write out stripe footer.
- findClosestNumBits(long) - Method in class org.apache.orc.impl.SerializationUtils
-
Count the number of bits required to encode the given value
- findColumn(TypeDescription, List<String>, boolean, ParserUtils.TypeVisitor) - Static method in class org.apache.orc.impl.ParserUtils
-
Find a column in a schema by walking down the type tree to find the right column.
- findColumn(TypeDescription, ParserUtils.StringPosition, boolean, ParserUtils.TypeVisitor) - Static method in class org.apache.orc.impl.ParserUtils
-
Find a column in a schema by walking down the type tree to find the right column.
- findColumnVector(String) - Method in class org.apache.orc.impl.OrcFilterContextImpl
- findColumnVector(String) - Method in interface org.apache.orc.OrcFilterContext
-
Retrieves the column vector that matches the specified name.
- findColumnVectors(TypeDescription, ParserUtils.StringPosition, boolean, VectorizedRowBatch) - Static method in class org.apache.orc.impl.ParserUtils
- findLastCharacter(byte[], int, int) - Static method in class org.apache.orc.impl.Utf8Utils
-
Find the start of the last character that ends in the current string.
- findSubtype(int) - Method in class org.apache.orc.TypeDescription
-
Locate a subtype by its id.
- findSubtype(String) - Method in class org.apache.orc.TypeDescription
-
Find a subtype of this schema by name.
- findSubtype(String, boolean) - Method in class org.apache.orc.TypeDescription
- findSubtype(TypeDescription, int, ParserUtils.TypeVisitor) - Static method in class org.apache.orc.impl.ParserUtils
- findSubtype(TypeDescription, ParserUtils.StringPosition) - Static method in class org.apache.orc.impl.ParserUtils
- findSubtype(TypeDescription, ParserUtils.StringPosition, boolean) - Static method in class org.apache.orc.impl.ParserUtils
- findSubtypeList(TypeDescription, ParserUtils.StringPosition) - Static method in class org.apache.orc.impl.ParserUtils
- findSubtypes(String) - Method in class org.apache.orc.TypeDescription
-
Find a list of subtypes from a string, including the empty list.
- firstChunk - Variable in class org.apache.orc.impl.reader.StripePlanner.StreamInformation
- FIVE - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- FLOAT - Enum constant in enum class org.apache.orc.TypeDescription.Category
- FloatTreeReader(int, InStream, InStream, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.FloatTreeReader
- FloatTreeWriter - Class in org.apache.orc.impl.writer
- FloatTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.FloatTreeWriter
- flush() - Method in class org.apache.orc.impl.BitFieldWriter
- flush() - Method in interface org.apache.orc.impl.IntegerWriter
-
Flush the buffer
- flush() - Method in class org.apache.orc.impl.OutStream
- flush() - Method in class org.apache.orc.impl.PhysicalFsWriter
- flush() - Method in class org.apache.orc.impl.RunLengthByteWriter
- flush() - Method in class org.apache.orc.impl.RunLengthIntegerWriter
- flush() - Method in class org.apache.orc.impl.RunLengthIntegerWriterV2
- flush() - Method in interface org.apache.orc.PhysicalWriter
-
Flushes the writer so that readers can see the preceding postscripts.
- flushStreams() - Method in class org.apache.orc.impl.writer.BinaryTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.BooleanTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.ByteTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.DateTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.Decimal64TreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.DecimalTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.DoubleTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.FloatTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.IntegerTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.ListTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.MapTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.StringBaseTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.StructTreeWriter
- flushStreams() - Method in class org.apache.orc.impl.writer.TimestampTreeWriter
- flushStreams() - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Flush the TreeWriter stream
- flushStreams() - Method in class org.apache.orc.impl.writer.TreeWriterBase
- flushStreams() - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- FOLLOWERS - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
- FOLLOWERS_AND_PARENTS - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
- FOOTER - Enum constant in enum class org.apache.orc.impl.StreamName.Area
- FORCE_POSITIONAL_EVOLUTION - Enum constant in enum class org.apache.orc.OrcConf
- FORCE_POSITIONAL_EVOLUTION_LEVEL - Enum constant in enum class org.apache.orc.OrcConf
- forcePositionalEvolution(boolean) - Method in class org.apache.orc.Reader.Options
-
Set whether to force schema evolution to be positional instead of based on the column names.
- FORTY - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- FORTYEIGHT - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- FOUR - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- FOURTEEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- from(int) - Static method in enum class org.apache.orc.OrcFile.WriterImplementation
- from(TemporalAccessor) - Static method in class org.threeten.extra.chrono.HybridDate
-
Obtains a
HybridDate
from a temporal object. - from(OrcFile.WriterImplementation, int) - Static method in enum class org.apache.orc.OrcFile.WriterVersion
-
Convert the integer from OrcProto.PostScript.writerVersion to the enumeration with unknown versions being mapped to FUTURE.
- from(OrcProto.ColumnEncoding) - Static method in enum class org.apache.orc.util.BloomFilterIO.Encoding
- fromPosition(int) - Method in class org.apache.orc.impl.ParserUtils.StringPosition
- fromString(String) - Static method in enum class org.apache.orc.OrcFile.BloomFilterVersion
- fromString(String) - Static method in class org.apache.orc.TypeDescription
-
Parse TypeDescription from the Hive type names.
- FUTURE - Enum constant in enum class org.apache.orc.OrcFile.Version
-
The generic identifier for all unknown versions.
- FUTURE - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- FUTURE - Enum constant in enum class org.apache.orc.util.BloomFilterIO.Encoding
G
- get() - Method in class org.apache.orc.impl.BufferChunkList
- get() - Method in class org.apache.orc.impl.DynamicByteArray
-
Gets all the bytes of the array.
- get() - Static method in class org.apache.orc.impl.HadoopShimsFactory
- get(int) - Method in class org.apache.orc.impl.BufferChunkList
-
Get the nth element of the list
- get(int) - Method in class org.apache.orc.impl.DynamicByteArray
- get(int) - Method in class org.apache.orc.impl.DynamicIntArray
- get(int) - Method in class org.apache.orc.util.BloomFilter.BitSet
-
Returns true if the bit is set in the specified index.
- get(int, int) - Method in class org.apache.orc.impl.DynamicByteArray
- getAlgorithm() - Method in interface org.apache.orc.EncryptionKey
-
The encryption algorithm for this key.
- getAlgorithm() - Method in class org.apache.orc.impl.InStream.StreamOptions
- getAlgorithm() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- getAlgorithm() - Method in class org.apache.orc.impl.writer.StreamOptions
- getAlgorithm() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- getAllocationScale() - Method in class org.apache.orc.impl.MemoryManagerImpl
-
The scaling factor for each allocation to ensure that the pool isn't oversubscribed.
- getArea() - Method in class org.apache.orc.impl.StreamName
- getArea(OrcProto.Stream.Kind) - Static method in class org.apache.orc.impl.StreamName
- getAttribute() - Method in enum class org.apache.orc.OrcConf
- getAttributeNames() - Method in class org.apache.orc.TypeDescription
-
Get the list of attribute names defined on this type.
- getAttributeValue(String) - Method in class org.apache.orc.TypeDescription
-
Get the value of a given attribute.
- getBaseRow(TypeDescription) - Static method in class org.apache.orc.impl.SchemaEvolution
-
Get the underlying base row from an ACID event struct.
- getBaseTimestamp(String) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- getBitSet() - Method in class org.apache.orc.util.BloomFilter
- getBitSize() - Method in class org.apache.orc.util.BloomFilter
- getBlockPadding() - Method in class org.apache.orc.OrcFile.WriterOptions
- getBlockSize() - Method in class org.apache.orc.OrcFile.WriterOptions
- getBloomFilterColumns() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the bloom filter columns
- getBloomFilterColumns() - Method in class org.apache.orc.OrcFile.WriterOptions
- getBloomFilterFpp() - Method in class org.apache.orc.OrcFile.WriterOptions
- getBloomFilterFPP() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get bloom filter false positive percentage.
- getBloomFilterIndex() - Method in class org.apache.orc.impl.OrcIndex
- getBloomFilterKinds() - Method in class org.apache.orc.impl.OrcIndex
- getBloomFilterVersion() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Deprecated.
- getBloomFilterVersion() - Method in class org.apache.orc.OrcFile.WriterOptions
-
Deprecated.
- getBoolean(Properties, Configuration) - Method in enum class org.apache.orc.OrcConf
- getBoolean(Configuration) - Method in enum class org.apache.orc.OrcConf
- getBuffer(boolean, int) - Method in class org.apache.orc.impl.RecordReaderUtils.ByteBufferAllocatorPool
- getBuffer(int) - Static method in class org.apache.orc.impl.AircompressorCodec
- getBuffer(int) - Static method in class org.apache.orc.impl.ZstdCodec
- getBufferSize() - Method in class org.apache.orc.impl.InStream.StreamOptions
- getBufferSize() - Method in class org.apache.orc.impl.OutStream
- getBufferSize() - Method in class org.apache.orc.impl.PositionedOutputStream
-
Get the memory size currently allocated as buffer associated with this stream.
- getBufferSize() - Method in class org.apache.orc.impl.writer.StreamOptions
- getBufferSize() - Method in class org.apache.orc.OrcFile.WriterOptions
- getBytesOnDisk() - Method in interface org.apache.orc.ColumnStatistics
-
Get the number of bytes for this column.
- getBytesOnDisk() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
-
Get the number of bytes for this column.
- getCalendarType() - Method in class org.threeten.extra.chrono.HybridChronology
-
Gets the calendar type of the underlying calendar system, which returns null.
- getCallback() - Method in class org.apache.orc.OrcFile.WriterOptions
- getCategory() - Method in class org.apache.orc.TypeDescription
-
Get the kind of this type.
- getCharacterSize() - Method in class org.apache.orc.impl.StringRedBlackTree
-
Get the size of the character data in the table.
- getChildReaders() - Method in class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- getChildren() - Method in class org.apache.orc.TypeDescription
-
Get the subtypes of this type.
- getChronology() - Method in class org.threeten.extra.chrono.HybridDate
-
Gets the chronology of this date, which is the British Cutover calendar system.
- getClosestAlignedFixedBits(int) - Method in class org.apache.orc.impl.SerializationUtils
- getClosestFixedBits(int) - Method in class org.apache.orc.impl.SerializationUtils
-
For a given fixed bit this function will return the closest available fixed bit
- getCodec() - Method in class org.apache.orc.impl.InStream.StreamOptions
- getCodec() - Method in class org.apache.orc.impl.writer.StreamOptions
- getCodec(CompressionKind) - Static method in class org.apache.orc.impl.OrcCodecPool
- getCodecOptions() - Method in class org.apache.orc.impl.writer.StreamOptions
- getCodePoint(byte[], int, int) - Static method in class org.apache.orc.impl.Utf8Utils
-
Get the code point at a given location in the byte array.
- getColName() - Method in class org.apache.orc.impl.filter.LeafFilter
- getCols() - Method in class org.apache.orc.impl.OrcFilterContextImpl
- getColumn() - Method in class org.apache.orc.impl.StreamName
- getColumn(int) - Method in class org.apache.orc.StripeStatistics
- getColumnCount() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getColumnEncryptionKeys() - Method in class org.apache.orc.impl.ReaderImpl
- getColumnEncryptionKeys() - Method in interface org.apache.orc.Reader
-
Get the list of encryption keys for column encryption.
- getColumnFilterCallback() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getColumnFilterCallback() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getColumnFilterIds() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getColumnFilterIds() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getColumnId() - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- getColumnId() - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- getColumnNames() - Method in interface org.apache.orc.filter.BatchFilter
-
Identifies the filter column names.
- getColumnNames() - Method in class org.apache.orc.Reader.Options
- getColumns() - Method in interface org.apache.orc.DataMaskDescription
-
Get the list of columns that use this mask.
- getColumns() - Method in class org.apache.orc.impl.MaskDescriptionImpl
- getColumnStatistics() - Method in class org.apache.orc.StripeStatistics
-
Return list of column statistics
- getCompress() - Method in class org.apache.orc.OrcFile.WriterOptions
- getCompression() - Method in class org.apache.orc.impl.DataReaderProperties
- getCompressionBlockSize(OrcProto.PostScript) - Static method in class org.apache.orc.impl.ReaderImpl
-
Read compression block size from the postscript if it is set; otherwise, use the same 256k default the C++ implementation uses.
- getCompressionBufferSize() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getCompressionBufferSize() - Method in class org.apache.orc.impl.OrcTail
- getCompressionCodec() - Method in class org.apache.orc.impl.RecordReaderImpl
- getCompressionCodec() - Method in class org.apache.orc.impl.WriterImpl
- getCompressionKind() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getCompressionKind() - Method in class org.apache.orc.impl.OrcTail
- getCompressionKind() - Method in class org.apache.orc.impl.ReaderImpl
- getCompressionKind() - Method in interface org.apache.orc.Reader
-
Get the compression kind.
- getCompressionOptions() - Method in interface org.apache.orc.DataReader
-
Returns the compression options used by this DataReader.
- getCompressionSize() - Method in class org.apache.orc.impl.ReaderImpl
- getCompressionSize() - Method in interface org.apache.orc.Reader
-
Get the buffer size for the compression.
- getCompressionStrategy() - Method in class org.apache.orc.OrcFile.WriterOptions
- getCompressionZstdLevel() - Method in class org.apache.orc.OrcFile.ZstdCompressOptions
- getCompressionZstdWindowLog() - Method in class org.apache.orc.OrcFile.ZstdCompressOptions
- getConfiguration() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the writer's configuration.
- getConfiguration() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getConfiguration() - Method in class org.apache.orc.OrcFile.WriterOptions
- getContentLength() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getContentLength() - Method in class org.apache.orc.impl.ReaderImpl
- getContentLength() - Method in interface org.apache.orc.Reader
-
Get the length of the file.
- getConvertToProlepticGregorian() - Method in class org.apache.orc.impl.ReaderImpl
- getConvertToProlepticGregorian() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getConvertToProlepticGregorian() - Method in interface org.apache.orc.Reader
-
Should the returned values use the proleptic Gregorian calendar?
- getCurrentKeyVersion(String) - Method in class org.apache.orc.InMemoryKeystore
-
Get the current metadata for a given key.
- getCurrentStatistics(ColumnStatistics[]) - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- getCurrentStatistics(ColumnStatistics[]) - Method in class org.apache.orc.impl.writer.ListTreeWriter
- getCurrentStatistics(ColumnStatistics[]) - Method in class org.apache.orc.impl.writer.MapTreeWriter
- getCurrentStatistics(ColumnStatistics[]) - Method in class org.apache.orc.impl.writer.StructTreeWriter
- getCurrentStatistics(ColumnStatistics[]) - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Get the current file statistics for each column.
- getCurrentStatistics(ColumnStatistics[]) - Method in class org.apache.orc.impl.writer.TreeWriterBase
- getCurrentStatistics(ColumnStatistics[]) - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- getCustomizedCodec(StreamOptions, OrcFile.CompressionStrategy, OrcProto.Stream.Kind) - Static method in class org.apache.orc.impl.SerializationUtils
-
Get the stream options with the compression tuned for the particular kind of stream.
- getCutover() - Method in class org.threeten.extra.chrono.HybridChronology
-
Gets the cutover date between the Julian and Gregorian calendar.
- getData() - Method in class org.apache.orc.impl.BufferChunk
- getData() - Method in class org.apache.orc.util.BloomFilter.BitSet
- getDataLength() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getDataLength() - Method in interface org.apache.orc.StripeInformation
-
Get the length of the stripe's data.
- getDataMasks() - Method in class org.apache.orc.impl.ReaderImpl
- getDataMasks() - Method in interface org.apache.orc.Reader
-
Get the data masks for the unencrypted variant of the data.
- getDataReader() - Method in class org.apache.orc.Reader.Options
- getDefaultOptions() - Method in interface org.apache.orc.CompressionCodec
-
Get the default options for this codec.
- getDefaultOptions() - Method in class org.apache.orc.impl.AircompressorCodec
- getDefaultOptions() - Method in class org.apache.orc.impl.BrotliCodec
- getDefaultOptions() - Method in class org.apache.orc.impl.ZlibCodec
- getDefaultOptions() - Method in class org.apache.orc.impl.ZstdCodec
- getDefaultValue() - Method in enum class org.apache.orc.OrcConf
- getDescription() - Method in enum class org.apache.orc.OrcConf
- getDescription(String...) - Method in enum class org.apache.orc.DataMask.Standard
-
Build a DataMaskDescription given the name and a set of parameters.
- getDictionaryKeySizeThreshold(int) - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the dictionary key size threshold.
- getDirectEncodingColumns() - Method in class org.apache.orc.OrcFile.WriterOptions
- getDouble(Properties, Configuration) - Method in enum class org.apache.orc.OrcConf
- getDouble(Configuration) - Method in enum class org.apache.orc.OrcConf
- getEncoding(int) - Method in class org.apache.orc.impl.reader.StripePlanner
- getEncodings() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getEncodingStrategy() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the encoding strategy to use.
- getEncodingStrategy() - Method in class org.apache.orc.OrcFile.WriterOptions
- getEncryptedLocalKeys() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getEncryptedLocalKeys() - Method in interface org.apache.orc.StripeInformation
-
Get the encrypted keys starting from this stripe until overridden by a new set in a following stripe.
- getEncryption() - Method in class org.apache.orc.impl.ReaderImpl
-
Internal access to our view of the encryption.
- getEncryption() - Method in class org.apache.orc.impl.StreamName
-
Get the encryption information for this stream.
- getEncryption() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getEncryption() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getEncryption() - Method in class org.apache.orc.OrcFile.WriterOptions
- getEncryption(int) - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the encryption for the given column.
- getEncryptionRoots() - Method in interface org.apache.orc.EncryptionKey
-
The columns that are encrypted with this key.
- getEncryptionRoots() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- getEncryptionRoots() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- getEncryptionStripeId() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getEncryptionStripeId() - Method in interface org.apache.orc.StripeInformation
-
Get the original stripe id that was used when the stripe was originally written.
- getEncryptionVariants() - Method in class org.apache.orc.impl.ReaderImpl
- getEncryptionVariants() - Method in interface org.apache.orc.Reader
-
Get the list of encryption variants for the data.
- getEra() - Method in class org.threeten.extra.chrono.HybridDate
-
Gets the era applicable at this date.
- getEstimatedBufferSize(long, int, int) - Static method in class org.apache.orc.impl.WriterImpl
- getFalseCount() - Method in interface org.apache.orc.BooleanColumnStatistics
- getFieldNames() - Method in class org.apache.orc.TypeDescription
-
For struct types, get the list of field names.
- getFile() - Method in class org.apache.orc.impl.DataReaderProperties
- getFileBytes(int) - Method in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
-
Computed the size of the given column on disk for this stripe.
- getFileBytes(int, WriterEncryptionVariant) - Method in class org.apache.orc.impl.PhysicalFsWriter
-
Get the number of bytes for a file in a given column by finding all the streams (not suppressed) for a given column and returning the sum of their sizes.
- getFileBytes(int, WriterEncryptionVariant) - Method in interface org.apache.orc.PhysicalWriter
-
Get the number of bytes for a file in a given column.
- getFileFooterKey() - Method in interface org.apache.orc.EncryptionVariant
-
Get the local key for the footer.
- getFileFooterKey() - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- getFileFooterKey() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getFileFormat() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getFileFormat() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getFileIncluded() - Method in class org.apache.orc.impl.SchemaEvolution
-
Get whether each column is included from the file's point of view.
- getFileKey() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getFileLength() - Method in class org.apache.orc.impl.OrcTail
-
Get the position of the end of the file.
- getFileMetadata() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getFileModificationTime() - Method in class org.apache.orc.impl.OrcTail
- getFileSchema() - Method in class org.apache.orc.impl.SchemaEvolution
- getFileStatistics() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getFileStats() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getFileStatus(Path) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- getFilesystem() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getFileSystem() - Method in class org.apache.orc.impl.ReaderImpl
- getFileSystem() - Method in class org.apache.orc.OrcFile.WriterOptions
- getFileSystemSupplier() - Method in class org.apache.orc.impl.DataReaderProperties
- getFileSystemSupplier() - Method in class org.apache.orc.impl.ReaderImpl
- getFileTail() - Method in class org.apache.orc.impl.OrcTail
- getFileTail() - Method in class org.apache.orc.impl.ReaderImpl
- getFileTail() - Method in interface org.apache.orc.Reader
-
Get the file tail (footer + postscript)
- getFileType(int) - Method in class org.apache.orc.impl.SchemaEvolution
-
Get the file type by reader type id.
- getFileType(TypeDescription) - Method in class org.apache.orc.impl.SchemaEvolution
- getFileVersion() - Method in class org.apache.orc.impl.ReaderImpl
- getFileVersion() - Method in interface org.apache.orc.Reader
-
Get the file format version.
- getFileVersion(List<Integer>) - Static method in class org.apache.orc.impl.ReaderImpl
- getFilter(String, Configuration) - Method in interface org.apache.orc.filter.PluginFilterService
-
Determine the filter for a given read path.
- getFilterCallback() - Method in class org.apache.orc.Reader.Options
- getFlattenedColumnCount() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getFooter() - Method in class org.apache.orc.impl.OrcTail
- getFooterLength() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getFooterLength() - Method in interface org.apache.orc.StripeInformation
-
Get the length of the stripe's tail section, which contains its index.
- getForcePositionalEvolution() - Method in class org.apache.orc.Reader.Options
- getFullFieldName() - Method in class org.apache.orc.TypeDescription
-
Get the full field name for the given type.
- getHadoopShims() - Method in class org.apache.orc.OrcFile.WriterOptions
- getHiveConfName() - Method in enum class org.apache.orc.OrcConf
- getId() - Method in class org.apache.orc.impl.MaskDescriptionImpl
- getId() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- getId() - Method in enum class org.apache.orc.OrcFile.WriterImplementation
- getId() - Method in enum class org.apache.orc.OrcFile.WriterVersion
- getId() - Method in class org.apache.orc.TypeDescription
-
Get the id for this type.
- getId() - Method in enum class org.apache.orc.util.BloomFilterIO.Encoding
- getId() - Method in class org.threeten.extra.chrono.HybridChronology
-
Gets the ID of the chronology - 'Hybrid'.
- getInclude() - Method in class org.apache.orc.Reader.Options
- getIncludeAcidColumns() - Method in class org.apache.orc.Reader.Options
- getIndexLength() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getIndexLength() - Method in interface org.apache.orc.StripeInformation
-
Get the length of the stripe's indexes.
- getIndexPosition(OrcProto.ColumnEncoding.Kind, TypeDescription.Category, OrcProto.Stream.Kind, boolean, boolean) - Static method in class org.apache.orc.impl.RecordReaderUtils
-
Get the offset in the index positions for the column that the given stream starts.
- getInt(Properties, Configuration) - Method in enum class org.apache.orc.OrcConf
- getInt(Configuration) - Method in enum class org.apache.orc.OrcConf
- getInt(Configuration, int) - Method in enum class org.apache.orc.OrcConf
-
Deprecated.Use
OrcConf.getInt(Configuration)
instead. This method was incorrectly added and shouldn't be used anymore. - getIsParseError() - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- getIsSchemaEvolutionCaseAware() - Method in class org.apache.orc.Reader.Options
- getIv() - Method in class org.apache.orc.impl.InStream.StreamOptions
- getIv() - Method in class org.apache.orc.impl.writer.StreamOptions
- getKey() - Method in class org.apache.orc.impl.InStream.StreamOptions
- getKey() - Method in class org.apache.orc.impl.writer.StreamOptions
- getKeyDescription() - Method in interface org.apache.orc.EncryptionVariant
-
Get the key description for this column.
- getKeyDescription() - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- getKeyDescription() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getKeyName() - Method in interface org.apache.orc.EncryptionKey
-
The name of the key.
- getKeyName() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- getKeyName() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- getKeyNames() - Method in class org.apache.orc.InMemoryKeystore
-
Get the list of key names from the key provider.
- getKeyOverrides() - Method in class org.apache.orc.OrcFile.WriterOptions
- getKeyProvider() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getKeyProvider() - Method in class org.apache.orc.OrcFile.WriterOptions
- getKeyProvider(Configuration, Random) - Static method in class org.apache.orc.impl.CryptoUtils
-
Create a KeyProvider.
- getKeys() - Method in class org.apache.orc.impl.reader.ReaderEncryption
- getKeyVersion() - Method in interface org.apache.orc.EncryptionKey
-
The version of the key.
- getKeyVersion() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- getKeyVersion() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- getKind() - Method in interface org.apache.orc.CompressionCodec
-
Get the compression kind.
- getKind() - Method in class org.apache.orc.impl.AircompressorCodec
- getKind() - Method in class org.apache.orc.impl.BrotliCodec
- getKind() - Method in class org.apache.orc.impl.StreamName
- getKind() - Method in class org.apache.orc.impl.ZlibCodec
- getKind() - Method in class org.apache.orc.impl.ZstdCodec
- getKind() - Method in class org.apache.orc.InMemoryKeystore
- getLastFlushLength(FileSystem, Path) - Static method in class org.apache.orc.impl.OrcAcidUtils
-
Read the side file to get the last flush length.
- getLeft(int) - Method in class org.apache.orc.impl.StringRedBlackTree
-
Get the left field of the given position.
- getLength() - Method in interface org.apache.orc.impl.Dictionary.VisitorContext
-
Get the number of bytes.
- getLength() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getLength() - Method in class org.apache.orc.impl.VisitorContextImpl
- getLength() - Method in class org.apache.orc.Reader.Options
- getLength() - Method in interface org.apache.orc.StripeInformation
-
Get the total length of the stripe in bytes.
- getLengths() - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- getLong(TemporalField) - Method in class org.threeten.extra.chrono.HybridDate
- getLong(Properties, Configuration) - Method in enum class org.apache.orc.OrcConf
- getLong(Configuration) - Method in enum class org.apache.orc.OrcConf
- getLowerBound() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
-
Get the string with length = Min(StringStatisticsImpl.MAX_BYTES_RECORDED, getMinimum())
- getLowerBound() - Method in interface org.apache.orc.StringColumnStatistics
-
Get the lower bound of the values in this column.
- getMajor() - Method in enum class org.apache.orc.OrcFile.Version
-
Get the major version number.
- getMasks() - Method in class org.apache.orc.impl.reader.ReaderEncryption
- getMasks() - Method in class org.apache.orc.OrcFile.WriterOptions
- getMaterial() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getMaxDiskRangeChunkLimit() - Method in class org.apache.orc.impl.DataReaderProperties
- getMaxDiskRangeChunkLimit() - Method in class org.apache.orc.impl.RecordReaderImpl
- getMaximum() - Method in interface org.apache.orc.DateColumnStatistics
-
Deprecated.Use #getMaximumLocalDate instead
- getMaximum() - Method in interface org.apache.orc.DecimalColumnStatistics
-
Get the maximum value for the column.
- getMaximum() - Method in interface org.apache.orc.DoubleColumnStatistics
-
Get the largest value in the column.
- getMaximum() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- getMaximum() - Method in interface org.apache.orc.IntegerColumnStatistics
-
Get the largest value in the column.
- getMaximum() - Method in interface org.apache.orc.StringColumnStatistics
-
Get the maximum string.
- getMaximum() - Method in interface org.apache.orc.TimestampColumnStatistics
-
Get the maximum value for the column.
- getMaximumChildren() - Method in interface org.apache.orc.CollectionColumnStatistics
-
Get maximum number of children in the collection.
- getMaximumDayOfEpoch() - Method in interface org.apache.orc.DateColumnStatistics
-
Get the maximum value for the column.
- getMaximumId() - Method in class org.apache.orc.TypeDescription
-
Get the maximum id assigned to this type or its children.
- getMaximumLocalDate() - Method in interface org.apache.orc.DateColumnStatistics
-
Get the maximum value for the column.
- getMaximumUTC() - Method in interface org.apache.orc.TimestampColumnStatistics
-
Get the maximum value for the column in UTC.
- getMaxLength() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getMaxLength() - Method in class org.apache.orc.TypeDescription
-
Get the maximum length of the type.
- getMaxOffset() - Method in class org.apache.orc.Reader.Options
- getMemoryManager() - Method in class org.apache.orc.OrcFile.WriterOptions
- getMetadata() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- getMetadata() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- getMetadataKeys() - Method in class org.apache.orc.impl.ReaderImpl
- getMetadataKeys() - Method in interface org.apache.orc.Reader
-
Get the user metadata keys.
- getMetadataOffset() - Method in class org.apache.orc.impl.OrcTail
-
Get the file offset of the metadata section of footer.
- getMetadataSize() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getMetadataSize() - Method in class org.apache.orc.impl.OrcTail
- getMetadataSize() - Method in class org.apache.orc.impl.ReaderImpl
- getMetadataSize() - Method in interface org.apache.orc.Reader
- getMetadataValue(String) - Method in class org.apache.orc.impl.ReaderImpl
- getMetadataValue(String) - Method in interface org.apache.orc.Reader
-
Get a user metadata value.
- getMinimalFileTail() - Method in class org.apache.orc.impl.OrcTail
- getMinimum() - Method in interface org.apache.orc.DateColumnStatistics
-
Deprecated.Use #getMinimumLocalDate instead
- getMinimum() - Method in interface org.apache.orc.DecimalColumnStatistics
-
Get the minimum value for the column.
- getMinimum() - Method in interface org.apache.orc.DoubleColumnStatistics
-
Get the smallest value in the column.
- getMinimum() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- getMinimum() - Method in interface org.apache.orc.IntegerColumnStatistics
-
Get the smallest value in the column.
- getMinimum() - Method in interface org.apache.orc.StringColumnStatistics
-
Get the minimum string.
- getMinimum() - Method in interface org.apache.orc.TimestampColumnStatistics
-
Get the minimum value for the column.
- getMinimumChildren() - Method in interface org.apache.orc.CollectionColumnStatistics
-
Get minimum number of children in the collection.
- getMinimumDayOfEpoch() - Method in interface org.apache.orc.DateColumnStatistics
-
Get the minimum value for the column.
- getMinimumLocalDate() - Method in interface org.apache.orc.DateColumnStatistics
-
Get the minimum value for the column.
- getMinimumUTC() - Method in interface org.apache.orc.TimestampColumnStatistics
-
Get the minimum value for the column in UTC.
- getMinor() - Method in enum class org.apache.orc.OrcFile.Version
-
Get the minor version number.
- getMinSeekSize() - Method in class org.apache.orc.impl.DataReaderProperties
- getMinSeekSizeTolerance() - Method in class org.apache.orc.impl.DataReaderProperties
- getName() - Method in enum class org.apache.orc.DataMask.Standard
-
Get the name of the predefined data mask.
- getName() - Method in interface org.apache.orc.DataMaskDescription
-
The name of the mask.
- getName() - Method in class org.apache.orc.impl.MaskDescriptionImpl
- getName() - Method in enum class org.apache.orc.OrcFile.Version
-
Get the human readable name for the version.
- getName() - Method in enum class org.apache.orc.TypeDescription.Category
- getNext() - Method in interface org.apache.orc.impl.PositionProvider
- getNext() - Method in class org.apache.orc.impl.RecordReaderImpl.PositionProviderImpl
- getNext() - Method in class org.apache.orc.impl.RecordReaderImpl.ZeroPositionProvider
- getNumberOfRows() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getNumberOfRows() - Method in class org.apache.orc.impl.ReaderImpl
- getNumberOfRows() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getNumberOfRows() - Method in class org.apache.orc.impl.WriterImpl
-
Row count gets updated when flushing the stripes.
- getNumberOfRows() - Method in interface org.apache.orc.Reader
-
Get the number of rows in the file.
- getNumberOfRows() - Method in interface org.apache.orc.StripeInformation
-
Get the number of rows in the stripe.
- getNumberOfRows() - Method in interface org.apache.orc.Writer
-
Return the number of rows in file.
- getNumberOfValues() - Method in interface org.apache.orc.ColumnStatistics
-
Get the number of values in this column.
- getNumberOfValues() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- getNumHashFunctions() - Method in class org.apache.orc.util.BloomFilter
- getOffset() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getOffset() - Method in class org.apache.orc.Reader.Options
- getOffset() - Method in interface org.apache.orc.StripeInformation
-
Get the byte offset of the start of the stripe.
- getOrcProtoFileStatistics() - Method in class org.apache.orc.impl.ReaderImpl
- getOrcProtoFileStatistics() - Method in interface org.apache.orc.Reader
-
Deprecated.Use
Reader.getStatistics()
instead. - getOrcProtoStripeStatistics() - Method in class org.apache.orc.impl.ReaderImpl
- getOrcProtoStripeStatistics() - Method in interface org.apache.orc.Reader
-
Deprecated.Use
Reader.getStripeStatistics()
instead. - getOrcTail() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getOrcTypes(TypeDescription) - Static method in class org.apache.orc.OrcUtils
- getOrcVersion() - Static method in class org.apache.orc.OrcUtils
-
Get the software version from Maven.
- getOriginalPosition() - Method in interface org.apache.orc.impl.Dictionary.VisitorContext
-
Get the position where the key was originally added.
- getOriginalPosition() - Method in class org.apache.orc.impl.VisitorContextImpl
- getOverwrite() - Method in class org.apache.orc.OrcFile.WriterOptions
- getPaddingTolerance() - Method in class org.apache.orc.OrcFile.WriterOptions
- getParameters() - Method in interface org.apache.orc.DataMaskDescription
-
The parameters for the mask
- getParameters() - Method in class org.apache.orc.impl.MaskDescriptionImpl
- getParent() - Method in class org.apache.orc.TypeDescription
-
Get the parent of the current type
- getPath() - Method in class org.apache.orc.impl.DataReaderProperties
- getPath() - Method in exception org.apache.orc.UnknownFormatException
-
Deprecated.
- getPhysicalWriter() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the PhysicalWriter.
- getPhysicalWriter() - Method in class org.apache.orc.OrcFile.WriterOptions
- getPoolSize(CompressionKind) - Static method in class org.apache.orc.impl.OrcCodecPool
- getPosition(PositionRecorder) - Method in class org.apache.orc.impl.BitFieldWriter
- getPosition(PositionRecorder) - Method in interface org.apache.orc.impl.IntegerWriter
-
Get position from the stream.
- getPosition(PositionRecorder) - Method in class org.apache.orc.impl.OutStream
- getPosition(PositionRecorder) - Method in class org.apache.orc.impl.PositionedOutputStream
-
Record the current position to the recorder.
- getPosition(PositionRecorder) - Method in class org.apache.orc.impl.RunLengthByteWriter
- getPosition(PositionRecorder) - Method in class org.apache.orc.impl.RunLengthIntegerWriter
- getPosition(PositionRecorder) - Method in class org.apache.orc.impl.RunLengthIntegerWriterV2
- getPositionalColumns() - Method in class org.apache.orc.impl.SchemaEvolution
-
Get whether the columns are handled via position or name
- getPositionalEvolutionLevel() - Method in class org.apache.orc.Reader.Options
- getPostscript() - Method in exception org.apache.orc.UnknownFormatException
-
Deprecated.
- getPostScript() - Method in class org.apache.orc.impl.OrcTail
- getPrecision() - Method in class org.apache.orc.TypeDescription
-
Get the precision of the decimal type.
- getPreFilterColumnNames() - Method in class org.apache.orc.Reader.Options
- getPresent() - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- getProgress() - Method in class org.apache.orc.impl.RecordReaderImpl
-
Return the fraction of rows that have been read from the selected.
- getProgress() - Method in interface org.apache.orc.RecordReader
-
Get the progress of the reader through the rows.
- getProlepticGregorian() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Should we write the data using the proleptic Gregorian calendar?
- getProlepticGregorian() - Method in class org.apache.orc.OrcFile.WriterOptions
- getRawDataSize() - Method in class org.apache.orc.impl.ReaderImpl
- getRawDataSize() - Method in class org.apache.orc.impl.writer.BinaryTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.BooleanTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.ByteTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.DateTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.Decimal64TreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.DecimalTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.DoubleTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.FloatTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.IntegerTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.ListTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.MapTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.StringBaseTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.StructTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.writer.TimestampTreeWriter
- getRawDataSize() - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Estimate the memory used if the file was read into Hive's Writable types.
- getRawDataSize() - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- getRawDataSize() - Method in class org.apache.orc.impl.WriterImpl
-
Raw data size will be compute when writing the file footer.
- getRawDataSize() - Method in interface org.apache.orc.Reader
-
Get the deserialized data size of the file
- getRawDataSize() - Method in interface org.apache.orc.Writer
-
Return the deserialized data size.
- getRawDataSizeFromColIndices(List<Integer>) - Method in class org.apache.orc.impl.ReaderImpl
- getRawDataSizeFromColIndices(List<Integer>) - Method in interface org.apache.orc.Reader
-
Get the deserialized data size of the specified columns ids
- getRawDataSizeFromColIndices(List<Integer>, List<OrcProto.Type>, List<OrcProto.ColumnStatistics>) - Static method in class org.apache.orc.impl.ReaderImpl
- getRawDataSizeOfColumns(List<String>) - Method in class org.apache.orc.impl.ReaderImpl
- getRawDataSizeOfColumns(List<String>) - Method in interface org.apache.orc.Reader
-
Get the deserialized data size of the specified columns
- getReader() - Method in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- getReaderBaseSchema() - Method in class org.apache.orc.impl.SchemaEvolution
-
Returns the non-ACID (aka base) reader type description.
- getReaderCategory() - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- getReaderCategory() - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- getReaderCategory(int) - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getReaderCategory(int) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getReaderIncluded() - Method in class org.apache.orc.impl.SchemaEvolution
-
Get whether each column is included from the reader's point of view.
- getReaderSchema() - Method in class org.apache.orc.impl.SchemaEvolution
- getRight(int) - Method in class org.apache.orc.impl.StringRedBlackTree
-
Get the right field of the given position.
- getRoot() - Method in interface org.apache.orc.EncryptionVariant
-
Get the root column for this variant.
- getRoot() - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- getRoot() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getRowBatchSize() - Method in class org.apache.orc.Reader.Options
- getRowGroupIndex() - Method in class org.apache.orc.impl.OrcIndex
- getRowIndex() - Method in class org.apache.orc.impl.writer.TreeWriterBase
- getRowIndexEntry() - Method in class org.apache.orc.impl.writer.TreeWriterBase
- getRowIndexStride() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getRowIndexStride() - Method in class org.apache.orc.impl.ReaderImpl
- getRowIndexStride() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the stride rate of the row index.
- getRowIndexStride() - Method in class org.apache.orc.OrcFile.WriterOptions
- getRowIndexStride() - Method in interface org.apache.orc.Reader
-
Get the number of rows per a entry in the row index.
- getRowNumber() - Method in class org.apache.orc.impl.RecordReaderImpl
- getRowNumber() - Method in interface org.apache.orc.RecordReader
-
Get the row number of the row that will be returned by the following call to next().
- getScale() - Method in class org.apache.orc.TypeDescription
-
Get the scale of the decimal type.
- getSchema() - Method in class org.apache.orc.impl.OrcTail
- getSchema() - Method in class org.apache.orc.impl.ReaderImpl
- getSchema() - Method in class org.apache.orc.impl.WriterImpl
- getSchema() - Method in class org.apache.orc.OrcFile.WriterOptions
- getSchema() - Method in interface org.apache.orc.Reader
-
Get the type of rows in this ORC file.
- getSchema() - Method in class org.apache.orc.Reader.Options
- getSchema() - Method in interface org.apache.orc.Writer
-
Get the schema for this writer
- getSchemaEvolution() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getSchemaEvolution() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getSearchArgument() - Method in class org.apache.orc.Reader.Options
- getSelected() - Method in class org.apache.orc.impl.OrcFilterContextImpl
- getSelectedSize() - Method in class org.apache.orc.impl.OrcFilterContextImpl
- getSerializedFileFooter() - Method in class org.apache.orc.impl.ReaderImpl
- getSerializedFileFooter() - Method in interface org.apache.orc.Reader
- getSerializedTail() - Method in class org.apache.orc.impl.OrcTail
- getSideFile(Path) - Static method in class org.apache.orc.impl.OrcAcidUtils
-
Get the filename of the ORC ACID side file that contains the lengths of the intermediate footers.
- getSizeInBytes() - Method in interface org.apache.orc.impl.Dictionary
- getSizeInBytes() - Method in class org.apache.orc.impl.DynamicByteArray
-
Get the size of the buffers.
- getSizeInBytes() - Method in class org.apache.orc.impl.DynamicIntArray
- getSizeInBytes() - Method in class org.apache.orc.impl.StringHashTableDictionary
- getSizeInBytes() - Method in class org.apache.orc.impl.StringRedBlackTree
-
Calculate the approximate size in memory.
- getSkipCorruptRecords() - Method in class org.apache.orc.Reader.Options
- getSoftwareVersion() - Method in class org.apache.orc.impl.ReaderImpl
- getSoftwareVersion() - Method in interface org.apache.orc.Reader
-
Get the implementation and version of the software that wrote the file.
- getSoftwareVersion(int, String) - Static method in class org.apache.orc.OrcUtils
-
Get the user-facing version string for the software that wrote the file.
- getState() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- getStatistics() - Method in class org.apache.orc.impl.ReaderImpl
- getStatistics() - Method in class org.apache.orc.impl.WriterImpl
- getStatistics() - Method in interface org.apache.orc.Reader
-
Get the statistics about the columns in the file.
- getStatistics() - Method in interface org.apache.orc.Writer
-
Get the statistics about the columns in the file.
- getStream() - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- getStream(StreamName) - Method in class org.apache.orc.impl.reader.StripePlanner
-
Get the stream for the given name.
- getStreamOptions() - Method in class org.apache.orc.impl.PhysicalFsWriter
- getStreamOptions() - Method in interface org.apache.orc.PhysicalWriter
-
Get the unencrypted stream options for this file.
- getString(Properties, Configuration) - Method in enum class org.apache.orc.OrcConf
- getString(Configuration) - Method in enum class org.apache.orc.OrcConf
- getStringAsList(Configuration) - Method in enum class org.apache.orc.OrcConf
- getStripeId() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- getStripeId() - Method in interface org.apache.orc.StripeInformation
-
Get the index of this stripe in the current file.
- getStripeKey(long) - Method in interface org.apache.orc.EncryptionVariant
-
Get the local key for a stripe's data or footer.
- getStripeKey(long) - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- getStripeKey(long) - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getStripeRowCountValue() - Method in class org.apache.orc.OrcFile.WriterOptions
- getStripes() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getStripes() - Method in class org.apache.orc.impl.OrcTail
- getStripes() - Method in class org.apache.orc.impl.ReaderImpl
- getStripes() - Method in class org.apache.orc.impl.WriterImpl
- getStripes() - Method in interface org.apache.orc.Reader
-
Get the list of stripes.
- getStripes() - Method in interface org.apache.orc.Writer
-
Get the stripe information about the file.
- getStripeSize() - Method in class org.apache.orc.OrcFile.WriterOptions
- getStripeStatistics() - Method in class org.apache.orc.impl.OrcTail
-
Deprecated.the user should use Reader.getStripeStatistics instead.
- getStripeStatistics() - Method in class org.apache.orc.impl.ReaderImpl
- getStripeStatistics() - Method in class org.apache.orc.impl.writer.TreeWriterBase
- getStripeStatistics() - Method in interface org.apache.orc.Reader
-
Get the stripe statistics for all of the columns.
- getStripeStatistics(boolean[]) - Method in class org.apache.orc.impl.ReaderImpl
- getStripeStatistics(boolean[]) - Method in interface org.apache.orc.Reader
-
Get the stripe statistics from the file.
- getStripeStatistics(boolean[], InStream.StreamOptions, ReaderImpl) - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
-
Decrypt the raw data and return the list of the stripe statistics for this variant.
- getStripeStatisticsLength() - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- getStripeStatisticsOffset() - Method in class org.apache.orc.impl.OrcTail
-
Get the file offset of the stripe statistics.
- getStripeStats() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getSum() - Method in interface org.apache.orc.BinaryColumnStatistics
- getSum() - Method in interface org.apache.orc.DecimalColumnStatistics
-
Get the sum of the values of the column.
- getSum() - Method in interface org.apache.orc.DoubleColumnStatistics
-
Get the sum of the values in the column.
- getSum() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- getSum() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- getSum() - Method in interface org.apache.orc.IntegerColumnStatistics
-
Get the sum of the column.
- getSum() - Method in interface org.apache.orc.StringColumnStatistics
-
Get the total length of all strings
- getTailBuffer() - Method in class org.apache.orc.impl.OrcTail
-
Gets the buffer chunks that correspond to the stripe statistics, file tail, and post script.
- getText() - Method in interface org.apache.orc.impl.Dictionary.VisitorContext
-
Get the original string.
- getText() - Method in class org.apache.orc.impl.VisitorContextImpl
- getText(int) - Method in interface org.apache.orc.impl.Dictionary
- getText(int) - Method in class org.apache.orc.impl.StringHashTableDictionary
- getText(int) - Method in class org.apache.orc.impl.StringRedBlackTree
- getText(Text, int) - Method in interface org.apache.orc.impl.Dictionary
-
Given the position index, return the original string before being encoded.
- getText(Text, int) - Method in class org.apache.orc.impl.StringHashTableDictionary
- getText(Text, int) - Method in class org.apache.orc.impl.StringRedBlackTree
- getTextInternal(int, DynamicIntArray, DynamicByteArray) - Static method in class org.apache.orc.impl.DictionaryUtils
-
Return a
ByteBuffer
containing the data at a certain offset within aDynamicByteArray
. - getTextInternal(Text, int, DynamicIntArray, DynamicByteArray) - Static method in class org.apache.orc.impl.DictionaryUtils
-
Obtain the UTF8 string from the byteArray using the offset in index-array.
- getTimeFormat(boolean, boolean) - Static method in class org.apache.orc.impl.DateUtils
- getTolerateMissingSchema() - Method in class org.apache.orc.Reader.Options
- getTotalChildren() - Method in interface org.apache.orc.CollectionColumnStatistics
-
Get the total number of children in the collection.
- getTotalMemoryPool() - Method in class org.apache.orc.impl.MemoryManagerImpl
-
Get the total pool size that is available for ORC writers.
- getTrueCount() - Method in interface org.apache.orc.BooleanColumnStatistics
- getTypes() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getTypes() - Method in class org.apache.orc.impl.OrcTail
- getTypes() - Method in class org.apache.orc.impl.ReaderImpl
- getTypes() - Method in interface org.apache.orc.Reader
-
Deprecated.use getSchema instead
- getUnencryptedMask(int) - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the mask for the unencrypted variant.
- getUpperBound() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
-
Get the string with length = Min(StringStatisticsImpl.MAX_BYTES_RECORDED, getMaximum())
- getUpperBound() - Method in interface org.apache.orc.StringColumnStatistics
-
Get the upper bound of the values in this column.
- getUri() - Method in class org.apache.orc.util.StreamWrapperFileSystem
- getUseUTCTimestamp() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getUseUTCTimestamp() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getUseUTCTimestamp() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Should the writer use UTC as the timezone?
- getUseUTCTimestamp() - Method in class org.apache.orc.OrcFile.ReaderOptions
- getUseUTCTimestamp() - Method in class org.apache.orc.OrcFile.WriterOptions
- getUseZeroCopy() - Method in class org.apache.orc.Reader.Options
- getVariant(int) - Method in class org.apache.orc.impl.reader.ReaderEncryption
-
Get the variant for a given column that the user has access to.
- getVariantId() - Method in interface org.apache.orc.EncryptionVariant
-
Get the encryption variant id within the file.
- getVariantId() - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- getVariantId() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- getVariants() - Method in class org.apache.orc.impl.reader.ReaderEncryption
- getVariantStripeStatistics(EncryptionVariant) - Method in class org.apache.orc.impl.ReaderImpl
- getVariantStripeStatistics(EncryptionVariant) - Method in interface org.apache.orc.Reader
-
Get the stripe statistics for a given variant.
- getVersion() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Get the version of the file to write.
- getVersion() - Method in class org.apache.orc.OrcFile.WriterOptions
- getVersionList() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getVersionList() - Method in class org.apache.orc.impl.ReaderImpl
- getVersionList() - Method in interface org.apache.orc.Reader
- getVersionString() - Method in exception org.apache.orc.UnknownFormatException
-
Deprecated.
- getWorkingDirectory() - Method in class org.apache.orc.util.StreamWrapperFileSystem
- getWriter() - Method in interface org.apache.orc.OrcFile.WriterContext
- getWriterImplementation() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getWriterImplementation() - Method in enum class org.apache.orc.OrcFile.WriterVersion
- getWriterTimezone() - Method in class org.apache.orc.impl.reader.StripePlanner
- getWriterTimezone() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- getWriterTimezone() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- getWriterVersion() - Method in class org.apache.orc.impl.OrcTail
- getWriterVersion() - Method in class org.apache.orc.impl.ReaderImpl
- getWriterVersion() - Method in class org.apache.orc.OrcFile.WriterOptions
- getWriterVersion() - Method in interface org.apache.orc.Reader
-
Get the version of the writer of this file.
- getWriterVersion(int) - Static method in class org.apache.orc.impl.ReaderImpl
-
Get the WriterVersion based on the ORC file postscript.
- getWriterVersionNum() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- getWriteVariableLengthBlocks() - Method in class org.apache.orc.OrcFile.WriterOptions
- getZeroCopy() - Method in class org.apache.orc.impl.DataReaderProperties
- getZstdCompressOptions() - Method in class org.apache.orc.OrcFile.WriterOptions
- getZstdOptions() - Method in class org.apache.orc.impl.ZstdCodec
H
- HadoopKeyProviderFactory() - Constructor for class org.apache.orc.impl.CryptoUtils.HadoopKeyProviderFactory
- HadoopShimsFactory - Class in org.apache.orc.impl
-
The factory for getting the proper version of the Hadoop shims.
- HadoopShimsFactory() - Constructor for class org.apache.orc.impl.HadoopShimsFactory
- hasCharactersLeft() - Method in class org.apache.orc.impl.ParserUtils.StringPosition
- hasConversion() - Method in class org.apache.orc.impl.SchemaEvolution
-
Is there Schema Evolution data type conversion?
- hasData() - Method in class org.apache.orc.impl.BufferChunk
- hasEncryptionStripeId() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- hasEncryptionStripeId() - Method in interface org.apache.orc.StripeInformation
-
Does this stripe have an explicit encryption stripe id set?
- HASH - Enum constant in enum class org.apache.orc.impl.Dictionary.IMPL
- hash128(byte[]) - Static method in class org.apache.orc.util.Murmur3
-
Murmur3 128-bit variant.
- hash128(byte[], int, int, int) - Static method in class org.apache.orc.util.Murmur3
-
Murmur3 128-bit variant.
- hash32(byte[]) - Static method in class org.apache.orc.util.Murmur3
-
Murmur3 32-bit variant.
- hash32(byte[], int, int) - Static method in class org.apache.orc.util.Murmur3
-
Murmur3 32-bit variant.
- hash64(byte[]) - Static method in class org.apache.orc.util.Murmur3
-
Murmur3 64-bit variant.
- hash64(byte[], int, int) - Static method in class org.apache.orc.util.Murmur3
- hash64(byte[], int, int, int) - Static method in class org.apache.orc.util.Murmur3
-
Murmur3 64-bit variant.
- hashCode() - Method in class org.apache.orc.impl.BufferChunk
- hashCode() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- hashCode() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- hashCode() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- hashCode() - Method in class org.apache.orc.impl.MaskDescriptionImpl
- hashCode() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- hashCode() - Method in class org.apache.orc.impl.reader.ReaderEncryptionVariant
- hashCode() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- hashCode() - Method in class org.apache.orc.impl.StreamName
- hashCode() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- hashCode() - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- hashCode() - Method in class org.apache.orc.TypeDescription
- hashCode() - Method in class org.apache.orc.util.BloomFilter.BitSet
- hashCode() - Method in class org.apache.orc.util.BloomFilter
- hashCode() - Method in class org.threeten.extra.chrono.HybridDate
-
A hash code for this date.
- hasMetadataValue(String) - Method in class org.apache.orc.impl.ReaderImpl
- hasMetadataValue(String) - Method in interface org.apache.orc.Reader
-
Did the user set the given metadata value.
- hasNext() - Method in interface org.apache.orc.impl.IntegerReader
-
Check if there are any more values left.
- hasNext() - Method in class org.apache.orc.impl.RunLengthByteReader
- hasNext() - Method in class org.apache.orc.impl.RunLengthIntegerReader
- hasNext() - Method in class org.apache.orc.impl.RunLengthIntegerReaderV2
- hasNull() - Method in interface org.apache.orc.ColumnStatistics
-
Returns true if there are nulls in the scope of column statistics.
- hasNull() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- hasOverride(TypeDescription) - Method in interface org.apache.orc.DataMask.MaskOverrides
-
Should the current mask be overridden on a sub-column?
- HEADER_SIZE - Static variable in class org.apache.orc.impl.OutStream
- HIVE_12055 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- HIVE_13083 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- HIVE_4243 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
-
fixed stripe/file maximum statistics and string statistics to use utf8 for min/max
- HIVE_8732 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- HybridChronology - Class in org.threeten.extra.chrono
-
The Julian-Gregorian hybrid calendar system.
- HybridChronology() - Constructor for class org.threeten.extra.chrono.HybridChronology
-
Deprecated.Use the singleton
HybridChronology.INSTANCE
instead. - HybridDate - Class in org.threeten.extra.chrono
-
A date in the British Cutover calendar system.
I
- id - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- IGNORE_NON_UTF8_BLOOM_FILTERS - Enum constant in enum class org.apache.orc.OrcConf
- IllegalEvolutionException(String) - Constructor for exception org.apache.orc.impl.SchemaEvolution.IllegalEvolutionException
- include(boolean[]) - Method in class org.apache.orc.Reader.Options
-
Set the list of columns to read.
- INCLUDE_COLUMNS - Enum constant in enum class org.apache.orc.OrcConf
- includeAcidColumns(boolean) - Method in class org.apache.orc.Reader.Options
-
true
if acid metadata columns should be decoded otherwise they will be set tonull
. - includeColumns(String, TypeDescription) - Static method in class org.apache.orc.OrcUtils
-
Returns selected columns as a boolean array with true value set for specified column names.
- includeReaderColumn(int) - Method in class org.apache.orc.impl.SchemaEvolution
-
Should we read the given reader column?
- includes(OrcFile.WriterVersion) - Method in enum class org.apache.orc.OrcFile.WriterVersion
-
Does this file include the given fix or come from a different writer?
- increaseCompressionSize(int) - Method in class org.apache.orc.impl.WriterImpl
- increaseCompressionSize(int) - Method in interface org.apache.orc.impl.WriterInternal
-
Increase the buffer size for this writer.
- increment() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- increment(int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- increment(int, int) - Method in class org.apache.orc.impl.DynamicIntArray
- INDEX - Enum constant in enum class org.apache.orc.impl.StreamName.Area
- indexStatistics - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- INITIAL_DICTIONARY_SIZE - Static variable in interface org.apache.orc.impl.Dictionary
- InMemoryKeystore - Class in org.apache.orc
-
This is an in-memory implementation of
KeyProvider
. - InMemoryKeystore() - Constructor for class org.apache.orc.InMemoryKeystore
-
Create a new InMemoryKeystore.
- InMemoryKeystore(Random) - Constructor for class org.apache.orc.InMemoryKeystore
-
Create an InMemoryKeystore with the given random generator.
- insert(byte[]) - Method in class org.apache.orc.util.CuckooSetBytes
- inserts - Variable in class org.apache.orc.impl.AcidStats
- INSTANCE - Static variable in class org.threeten.extra.chrono.HybridChronology
-
Singleton instance for the Coptic chronology.
- InStream - Class in org.apache.orc.impl
- InStream(Object, long, long) - Constructor for class org.apache.orc.impl.InStream
- InStream.CompressedStream - Class in org.apache.orc.impl
- InStream.EncryptedStream - Class in org.apache.orc.impl
-
Implements a stream over an encrypted, but uncompressed stream.
- InStream.StreamOptions - Class in org.apache.orc.impl
- InStream.UncompressedStream - Class in org.apache.orc.impl
-
Implements a stream over an uncompressed stream.
- INT - Enum constant in enum class org.apache.orc.TypeDescription.Category
- IntegerColumnStatistics - Interface in org.apache.orc
-
Statistics for all of the integer columns, such as byte, short, int, and long.
- integerDownCastNeeded(TypeDescription, TypeDescription) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- IntegerReader - Interface in org.apache.orc.impl
-
Interface for reading integers.
- IntegerTreeWriter - Class in org.apache.orc.impl.writer
- IntegerTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.IntegerTreeWriter
- IntegerWriter - Interface in org.apache.orc.impl
-
Interface for writing integers.
- IntTreeReader(int, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- IOUtils - Class in org.apache.orc.impl
-
This is copied from commons-io project to cut the dependency from old Hadoop.
- IOUtils() - Constructor for class org.apache.orc.impl.IOUtils
- IS_SCHEMA_EVOLUTION_CASE_SENSITIVE - Enum constant in enum class org.apache.orc.OrcConf
- isAllowSARGToFilter() - Method in class org.apache.orc.Reader.Options
-
Get allowSARGToFilter value.
- isAvailable() - Method in interface org.apache.orc.EncryptionKey
-
Is the key available to this user?
- isAvailable() - Method in class org.apache.orc.impl.BrotliCodec
- isAvailable() - Method in interface org.apache.orc.impl.DirectDecompressionCodec
- isAvailable() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- isAvailable() - Method in class org.apache.orc.impl.SnappyCodec
- isAvailable() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- isAvailable() - Method in class org.apache.orc.impl.ZlibCodec
- isAvailable() - Method in class org.apache.orc.impl.ZstdCodec
- isBuildIndex() - Method in class org.apache.orc.OrcFile.WriterOptions
- isCompressed() - Method in class org.apache.orc.impl.InStream.StreamOptions
- isCompressed() - Method in interface org.apache.orc.impl.writer.WriterContext
-
Is the ORC file compressed?
- isDecimalAsLong(OrcFile.Version, int) - Static method in class org.apache.orc.impl.TreeReaderFactory
- isDictionary(OrcProto.Stream.Kind, OrcProto.ColumnEncoding) - Static method in class org.apache.orc.impl.RecordReaderUtils
-
Is this stream part of a dictionary?
- isEncrypted() - Method in class org.apache.orc.impl.writer.StreamOptions
- isEnforceBufferSize() - Method in class org.apache.orc.OrcFile.WriterOptions
- isLeapYear(long) - Method in class org.threeten.extra.chrono.HybridChronology
-
Checks if the specified year is a leap year.
- IsNotNullFilter - Class in org.apache.orc.impl.filter
- IsNotNullFilter(String) - Constructor for class org.apache.orc.impl.filter.IsNotNullFilter
- isNull(ColumnVector[], int) - Static method in interface org.apache.orc.OrcFilterContext
-
Utility method for determining if a particular row element in the vector branch is null.
- IsNullFilter - Class in org.apache.orc.impl.filter
- IsNullFilter(String) - Constructor for class org.apache.orc.impl.filter.IsNullFilter
- isOnlyImplicitConversion() - Method in class org.apache.orc.impl.SchemaEvolution
-
When there Schema Evolution data type conversion i.e.
- isOriginalFormat() - Method in interface org.apache.orc.FileMetadata
-
Deprecated.
- isPPDSafeConversion(int) - Method in class org.apache.orc.impl.SchemaEvolution
-
Check if column is safe for ppd evaluation
- isPresent - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- isPrimitive() - Method in enum class org.apache.orc.TypeDescription.Category
- isRed(int) - Method in class org.apache.orc.impl.StringRedBlackTree
-
Is the given node red as opposed to black? To prevent having an extra word in the data array, we just the low bit on the left child index.
- isSafeSubtract(long, long) - Method in class org.apache.orc.impl.SerializationUtils
- isSchemaEvolutionCaseAware() - Method in class org.apache.orc.impl.SchemaEvolution
- isSchemaEvolutionCaseAware(boolean) - Method in class org.apache.orc.Reader.Options
-
Set boolean flag to determine if the comparison of field names in schema evolution is case sensitive
- isSelectedInUse() - Method in class org.apache.orc.impl.OrcFilterContextImpl
- isSkipCorrupt() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- isSkipCorrupt() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- isStatsExists() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- isSumDefined() - Method in interface org.apache.orc.IntegerColumnStatistics
-
Is the sum defined? If the sum overflowed the counter this will be false.
- isTrackingDiskRanges() - Method in interface org.apache.orc.DataReader
-
Whether the user should release buffers created by readFileData.
- isUtfStartByte(byte) - Static method in class org.apache.orc.impl.Utf8Utils
-
Checks if b is the first byte of a UTF-8 character.
- isValidTypeTree(List<OrcProto.Type>, int) - Static method in class org.apache.orc.OrcUtils
-
Checks whether the list of protobuf types from the file are valid or not.
K
- KEY_PROVIDER - Enum constant in enum class org.apache.orc.OrcConf
- keyReader - Variable in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- kind - Variable in class org.apache.orc.impl.reader.StripePlanner.StreamInformation
- KRYO_SARG - Enum constant in enum class org.apache.orc.OrcConf
- KRYO_SARG_BUFFER - Enum constant in enum class org.apache.orc.OrcConf
L
- lastAdd - Variable in class org.apache.orc.impl.StringRedBlackTree
- LEADER_PARENTS - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
- LEADERS - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
- LeafFilter - Class in org.apache.orc.impl.filter
- LeafFilter(String, boolean) - Constructor for class org.apache.orc.impl.filter.LeafFilter
- LeafFilterFactory - Class in org.apache.orc.impl.filter.leaf
- length - Variable in class org.apache.orc.impl.InStream
- length - Variable in class org.apache.orc.impl.reader.StripePlanner.StreamInformation
- lengthOfMonth() - Method in class org.threeten.extra.chrono.HybridDate
-
Returns the length of the month represented by this date.
- lengthOfYear() - Method in class org.threeten.extra.chrono.HybridDate
-
Returns the length of the year represented by this date.
- lengthOutput - Variable in class org.apache.orc.impl.writer.StringBaseTreeWriter
- lengths - Variable in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- lengths - Variable in class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- lengths - Variable in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- lengths - Variable in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- LIST - Enum constant in enum class org.apache.orc.TypeDescription.Category
- ListIdentity - Class in org.apache.orc.impl.mask
-
A data mask for list types that applies the given masks to its children, but doesn't mask at this level.
- listStatus(Path) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- ListTreeReader(int, InStream, TreeReaderFactory.Context, InStream, OrcProto.ColumnEncoding, TypeReader) - Constructor for class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- ListTreeReader(int, TypeDescription, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- ListTreeWriter - Class in org.apache.orc.impl.writer
- load(byte[][]) - Method in class org.apache.orc.util.CuckooSetBytes
-
Insert all values in the input array into the set.
- localDateTime(TemporalAccessor) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a British Cutover local date-time from another date-time object.
- LOG - Static variable in class org.apache.orc.impl.RunLengthIntegerReaderV2
- LONG - Enum constant in enum class org.apache.orc.TypeDescription.Category
- longColVector - Variable in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromAnyIntegerTreeReader
- LongIdentity - Class in org.apache.orc.impl.mask
-
An identity data mask for integer types.
- LongIdentity() - Constructor for class org.apache.orc.impl.mask.LongIdentity
- LongTreeReader(int, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- lookup(byte[], int, int) - Method in class org.apache.orc.util.CuckooSetBytes
-
Return true if and only if the value in byte array b beginning at start and ending at start+len is present in the set.
- LZ4 - Enum constant in enum class org.apache.orc.CompressionKind
- LZO - Enum constant in enum class org.apache.orc.CompressionKind
M
- MAGIC - Static variable in class org.apache.orc.OrcFile
- MAP - Enum constant in enum class org.apache.orc.TypeDescription.Category
- MapIdentity - Class in org.apache.orc.impl.mask
-
A data mask for map types that applies the given masks to its children, but doesn't mask at this level.
- MAPRED_INPUT_SCHEMA - Enum constant in enum class org.apache.orc.OrcConf
- MAPRED_OUTPUT_SCHEMA - Enum constant in enum class org.apache.orc.OrcConf
- MAPRED_SHUFFLE_KEY_SCHEMA - Enum constant in enum class org.apache.orc.OrcConf
- MAPRED_SHUFFLE_VALUE_SCHEMA - Enum constant in enum class org.apache.orc.OrcConf
- mapSargColumnsToOrcInternalColIdx(List<PredicateLeaf>, SchemaEvolution) - Static method in class org.apache.orc.impl.RecordReaderImpl
-
Find the mapping from predicate leaves to columns.
- mapTranslatedSargColumns(List<OrcProto.Type>, List<PredicateLeaf>) - Static method in class org.apache.orc.impl.RecordReaderImpl
- MapTreeReader(int, InStream, TreeReaderFactory.Context, InStream, OrcProto.ColumnEncoding, TypeReader, TypeReader) - Constructor for class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- MapTreeReader(int, TypeDescription, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- MapTreeWriter - Class in org.apache.orc.impl.writer
- MASK_ATTRIBUTE - Static variable in class org.apache.orc.TypeDescription
- maskData(ColumnVector, ColumnVector, int, int) - Method in interface org.apache.orc.DataMask
-
Mask the given range of values
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.DecimalIdentity
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.DoubleIdentity
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.ListIdentity
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.LongIdentity
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.MapIdentity
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.NullifyMask
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.StructIdentity
- maskData(ColumnVector, ColumnVector, int, int) - Method in class org.apache.orc.impl.mask.UnionIdentity
- MaskDescriptionImpl - Class in org.apache.orc.impl
- MaskDescriptionImpl(int, OrcProto.DataMask) - Constructor for class org.apache.orc.impl.MaskDescriptionImpl
- MaskDescriptionImpl(String, String...) - Constructor for class org.apache.orc.impl.MaskDescriptionImpl
- maskDouble(double) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
-
Replace each digit in value with digit.
- MaskFactory - Class in org.apache.orc.impl.mask
-
A mask factory framework that automatically builds a recursive mask.
- MaskFactory() - Constructor for class org.apache.orc.impl.mask.MaskFactory
- maskLong(long) - Method in class org.apache.orc.impl.mask.RedactMaskFactory
-
Replace each digit in value with DIGIT_REPLACEMENT scaled to the matching number of digits.
- MaskProvider - Class in org.apache.orc.impl.mask
-
The Provider for all of the built-in data masks.
- MaskProvider() - Constructor for class org.apache.orc.impl.mask.MaskProvider
- masks(String) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the masks for the unencrypted data.
- MAX_ARRAY_SIZE - Static variable in class org.apache.orc.impl.IOUtils
-
The maximum size of array to allocate, value being the same as
Hashtable
- MAX_BYTES_RECORDED - Static variable in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- MAX_DECIMAL64 - Static variable in class org.apache.orc.TypeDescription
- MAX_DECIMAL64_PRECISION - Static variable in class org.apache.orc.TypeDescription
- MAX_FILE_LENGTH - Enum constant in enum class org.apache.orc.OrcConf
- maxLength(long) - Method in class org.apache.orc.OrcFile.ReaderOptions
- memory(MemoryManager) - Method in class org.apache.orc.OrcFile.WriterOptions
-
A public option to set the memory manager.
- MEMORY_POOL - Enum constant in enum class org.apache.orc.OrcConf
- MemoryManager - Class in org.apache.orc.impl
-
Deprecated.
- MemoryManager - Interface in org.apache.orc
-
A memory manager that keeps a global context of how many ORC writers there are and manages the memory between them.
- MemoryManager(Configuration) - Constructor for class org.apache.orc.impl.MemoryManager
-
Deprecated.
- MemoryManager.Callback - Interface in org.apache.orc
- MemoryManagerImpl - Class in org.apache.orc.impl
-
Implements a memory manager that keeps a global context of how many ORC writers there are and manages the memory between them.
- MemoryManagerImpl(long) - Constructor for class org.apache.orc.impl.MemoryManagerImpl
-
Create the memory manager
- MemoryManagerImpl(Configuration) - Constructor for class org.apache.orc.impl.MemoryManagerImpl
-
Create the memory manager.
- merge(ColumnStatisticsImpl) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- merge(ColumnStatisticsImpl) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- merge(ColumnStatisticsImpl) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- merge(BloomFilter) - Method in class org.apache.orc.util.BloomFilter
-
Merge the specified bloom filter with current bloom filter.
- mergeFiles(Path, OrcFile.WriterOptions, List<Path>) - Static method in class org.apache.orc.OrcFile
-
Merges multiple ORC files that all have the same schema to produce a single ORC file.
- MILLIS_PER_SECOND - Static variable in class org.apache.orc.impl.writer.TimestampTreeWriter
- MIN_DECIMAL64 - Static variable in class org.apache.orc.TypeDescription
- minSeekSize() - Method in class org.apache.orc.Reader.Options
- minSeekSize(int) - Method in class org.apache.orc.Reader.Options
- minSeekSizeTolerance() - Method in class org.apache.orc.Reader.Options
- minSeekSizeTolerance(double) - Method in class org.apache.orc.Reader.Options
- minus(long, TemporalUnit) - Method in class org.threeten.extra.chrono.HybridDate
- minus(TemporalAmount) - Method in class org.threeten.extra.chrono.HybridDate
- mkdirs(Path, FsPermission) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- modifyIv(Consumer<byte[]>) - Method in class org.apache.orc.impl.writer.StreamOptions
-
Modify the IV.
- modifyIvForStream(int, OrcProto.Stream.Kind, long) - Static method in class org.apache.orc.impl.CryptoUtils
-
Update the unique IV for each stream within a single key.
- modifyIvForStream(StreamName, long) - Static method in class org.apache.orc.impl.CryptoUtils
-
Update the unique IV for each stream within a single key.
- modifyIvForStripe(long) - Static method in class org.apache.orc.impl.CryptoUtils
-
Modify the IV for the given stripe id and make sure the low bytes are set to 0.
- Murmur3 - Class in org.apache.orc.util
-
Murmur3 is successor to Murmur2 fast non-crytographic hash algorithms.
- Murmur3() - Constructor for class org.apache.orc.util.Murmur3
N
- name - Variable in class org.apache.orc.impl.InStream
- nanos - Variable in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- next() - Method in class org.apache.orc.impl.BitFieldReader
- next() - Method in interface org.apache.orc.impl.IntegerReader
-
Return the next available value.
- next() - Method in class org.apache.orc.impl.RunLengthByteReader
- next() - Method in class org.apache.orc.impl.RunLengthIntegerReader
- next() - Method in class org.apache.orc.impl.RunLengthIntegerReaderV2
- nextBatch(VectorizedRowBatch) - Method in class org.apache.orc.impl.RecordReaderImpl
- nextBatch(VectorizedRowBatch) - Method in interface org.apache.orc.RecordReader
-
Read the next row batch.
- nextBatch(VectorizedRowBatch, int, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.BatchReader
-
Read the next batch of data from the file.
- nextBatch(VectorizedRowBatch, int, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.PrimitiveBatchReader
- nextBatch(VectorizedRowBatch, int, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.StructBatchReader
- nextVector(boolean[], int[], long) - Method in class org.apache.orc.impl.RunLengthByteReader
-
Read the next size bytes into the data array, skipping over any slots where isNull is true.
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromAnyIntegerTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromDecimalTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromDoubleTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromStringGroupTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromTimestampTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DateFromStringGroupTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DateFromTimestampTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromAnyIntegerTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromDecimalTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromDoubleTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromStringGroupTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromTimestampTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromAnyIntegerTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromDecimalTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromStringGroupTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromTimestampTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.FloatFromDoubleTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromAnyIntegerTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromBinaryTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromDateTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromDecimalTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromDoubleTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromStringGroupTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromTimestampTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromAnyIntegerTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromDateTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromDecimalTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromDoubleTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromStringGroupTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BooleanTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ByteTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.CharTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DoubleTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.FloatTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.NullTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
-
Populates the isNull vector array in the previousVector object based on the present stream values.
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- nextVector(ColumnVector, boolean[], int, FilterContext, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.VarcharTreeReader
- nextVector(ColumnVector, int[], int) - Method in interface org.apache.orc.impl.IntegerReader
-
Return the next available vector for values.
- nextVector(ColumnVector, int[], int) - Method in class org.apache.orc.impl.RunLengthIntegerReader
- nextVector(ColumnVector, int[], int) - Method in class org.apache.orc.impl.RunLengthIntegerReaderV2
- nextVector(ColumnVector, long[], int) - Method in interface org.apache.orc.impl.IntegerReader
-
Return the next available vector for values.
- nextVector(ColumnVector, long[], int) - Method in class org.apache.orc.impl.RunLengthIntegerReader
- nextVector(ColumnVector, long[], int) - Method in class org.apache.orc.impl.RunLengthIntegerReaderV2
- nextVector(ColumnVector, long[], long) - Method in class org.apache.orc.impl.RunLengthByteReader
- nextVector(LongColumnVector, long) - Method in class org.apache.orc.impl.BitFieldReader
- nextVector(LongColumnVector, FilterContext, long) - Method in class org.apache.orc.impl.BitFieldReader
- nextVector(TimestampColumnVector, boolean[], int) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- nextVector(TimestampColumnVector, boolean[], FilterContext, int) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- NINE - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- NINETEEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- NON_FILTER - Enum constant in enum class org.apache.orc.impl.reader.tree.TypeReader.ReaderCategory
- NONE - Enum constant in enum class org.apache.orc.CompressionKind
- noNulls(ColumnVector[]) - Static method in interface org.apache.orc.OrcFilterContext
-
Utility method for determining if the leaf vector of the branch can be treated as having noNulls.
- notifyWriters() - Method in class org.apache.orc.impl.MemoryManagerImpl
-
Deprecated.remove this method
- now() - Static method in class org.threeten.extra.chrono.HybridDate
-
Obtains the current
HybridDate
from the system clock in the default time-zone. - now(Clock) - Static method in class org.threeten.extra.chrono.HybridDate
-
Obtains the current
HybridDate
from the specified clock. - now(ZoneId) - Static method in class org.threeten.extra.chrono.HybridDate
-
Obtains the current
HybridDate
from the system clock in the specified time-zone. - NULL - Static variable in class org.apache.orc.impl.StringRedBlackTree
- NULL_HASHCODE - Static variable in class org.apache.orc.util.Murmur3
- NULLIFY - Enum constant in enum class org.apache.orc.DataMask.Standard
- NullifyMask - Class in org.apache.orc.impl.mask
-
Masking routine that converts every value to NULL.
- NullifyMask() - Constructor for class org.apache.orc.impl.mask.NullifyMask
- NullTreeReader(int, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.NullTreeReader
O
- of(int, int, int) - Static method in class org.threeten.extra.chrono.HybridDate
-
Obtains a
HybridDate
representing a date in the British Cutover calendar system from the proleptic-year, month-of-year and day-of-month fields. - offset - Variable in class org.apache.orc.impl.InStream
- offset - Variable in class org.apache.orc.impl.reader.StripePlanner.StreamInformation
- ONE - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- open() - Method in interface org.apache.orc.DataReader
-
Opens the DataReader, making it ready to use.
- open(Path, int) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- options - Variable in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
- options - Variable in class org.apache.orc.impl.ReaderImpl
- options() - Static method in class org.apache.orc.impl.InStream
- options() - Method in class org.apache.orc.impl.ReaderImpl
- options() - Method in interface org.apache.orc.Reader
-
Create a default options object that can be customized for creating a RecordReader.
- Options() - Constructor for class org.apache.orc.Reader.Options
- Options(Configuration) - Constructor for class org.apache.orc.Reader.Options
- ORC_101 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- ORC_135 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- ORC_14 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- ORC_203 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- ORC_517 - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- ORC_CPP - Enum constant in enum class org.apache.orc.OrcFile.WriterImplementation
- ORC_CPP_ORIGINAL - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- ORC_JAVA - Enum constant in enum class org.apache.orc.OrcFile.WriterImplementation
- ORC_MAX_DISK_RANGE_CHUNK_LIMIT - Enum constant in enum class org.apache.orc.OrcConf
- ORC_MIN_DISK_SEEK_SIZE - Enum constant in enum class org.apache.orc.OrcConf
- ORC_MIN_DISK_SEEK_SIZE_TOLERANCE - Enum constant in enum class org.apache.orc.OrcConf
- OrcAcidUtils - Class in org.apache.orc.impl
- OrcAcidUtils() - Constructor for class org.apache.orc.impl.OrcAcidUtils
- OrcCodecPool - Class in org.apache.orc.impl
-
A clone of Hadoop codec pool for ORC; cause it has its own codecs...
- OrcConf - Enum Class in org.apache.orc
-
Define the configuration properties that Orc understands.
- OrcFile - Class in org.apache.orc
-
Contains factory methods to read or write ORC files.
- OrcFile() - Constructor for class org.apache.orc.OrcFile
- OrcFile.BloomFilterVersion - Enum Class in org.apache.orc
- OrcFile.CompressionStrategy - Enum Class in org.apache.orc
- OrcFile.EncodingStrategy - Enum Class in org.apache.orc
- OrcFile.ReaderOptions - Class in org.apache.orc
- OrcFile.Version - Enum Class in org.apache.orc
-
Create a version number for the ORC file format, so that we can add non-forward compatible changes in the future.
- OrcFile.WriterCallback - Interface in org.apache.orc
- OrcFile.WriterContext - Interface in org.apache.orc
- OrcFile.WriterImplementation - Enum Class in org.apache.orc
- OrcFile.WriterOptions - Class in org.apache.orc
-
Options for creating ORC file writers.
- OrcFile.WriterVersion - Enum Class in org.apache.orc
-
Records the version of the writer in terms of which bugs have been fixed.
- OrcFile.ZstdCompressOptions - Class in org.apache.orc
- OrcFilterContext - Interface in org.apache.orc
-
This defines the input for any filter operation.
- OrcFilterContextImpl - Class in org.apache.orc.impl
-
This defines the input for any filter operation.
- OrcFilterContextImpl(TypeDescription, boolean) - Constructor for class org.apache.orc.impl.OrcFilterContextImpl
- OrcIndex - Class in org.apache.orc.impl
- OrcIndex(OrcProto.RowIndex[], OrcProto.Stream.Kind[], OrcProto.BloomFilterIndex[]) - Constructor for class org.apache.orc.impl.OrcIndex
- orcTail(OrcTail) - Method in class org.apache.orc.OrcFile.ReaderOptions
- OrcTail - Class in org.apache.orc.impl
- OrcTail(OrcProto.FileTail, ByteBuffer) - Constructor for class org.apache.orc.impl.OrcTail
- OrcTail(OrcProto.FileTail, ByteBuffer, long) - Constructor for class org.apache.orc.impl.OrcTail
- OrcTail(OrcProto.FileTail, BufferChunk, long) - Constructor for class org.apache.orc.impl.OrcTail
- OrcTail(OrcProto.FileTail, BufferChunk, long, Reader) - Constructor for class org.apache.orc.impl.OrcTail
- OrcUtils - Class in org.apache.orc
- OrcUtils() - Constructor for class org.apache.orc.OrcUtils
- OrFilter - Class in org.apache.orc.impl.filter
- OrFilter(VectorFilter[]) - Constructor for class org.apache.orc.impl.filter.OrFilter
- org.apache.orc - package org.apache.orc
- org.apache.orc.filter - package org.apache.orc.filter
- org.apache.orc.impl - package org.apache.orc.impl
- org.apache.orc.impl.filter - package org.apache.orc.impl.filter
- org.apache.orc.impl.filter.leaf - package org.apache.orc.impl.filter.leaf
- org.apache.orc.impl.mask - package org.apache.orc.impl.mask
- org.apache.orc.impl.reader - package org.apache.orc.impl.reader
- org.apache.orc.impl.reader.tree - package org.apache.orc.impl.reader.tree
- org.apache.orc.impl.writer - package org.apache.orc.impl.writer
- org.apache.orc.util - package org.apache.orc.util
- org.threeten.extra.chrono - package org.threeten.extra.chrono
- ORIGINAL - Enum constant in enum class org.apache.orc.OrcFile.BloomFilterVersion
- ORIGINAL - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- ORIGINAL - Enum constant in enum class org.apache.orc.TypeDescription.RowBatchVersion
- ORIGINAL - Enum constant in enum class org.apache.orc.util.BloomFilterIO.Encoding
- output(ByteBuffer) - Method in interface org.apache.orc.PhysicalWriter.OutputReceiver
-
Output the given buffer to the final destination
- OutStream - Class in org.apache.orc.impl
-
The output stream for writing to ORC files.
- OutStream(Object, StreamOptions, PhysicalWriter.OutputReceiver) - Constructor for class org.apache.orc.impl.OutStream
- overwrite(boolean) - Method in class org.apache.orc.OrcFile.WriterOptions
-
If the output file already exists, should it be overwritten? If it is not provided, write operation will fail if the file already exists.
- OVERWRITE_OUTPUT_FILE - Enum constant in enum class org.apache.orc.OrcConf
P
- paddingTolerance(double) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Sets the tolerance for block padding as a percentage of stripe size.
- parseAcidStats(Reader) - Static method in class org.apache.orc.impl.OrcAcidUtils
- parseDate(String, boolean) - Static method in class org.apache.orc.impl.DateUtils
- parseDateFromString(String) - Static method in class org.apache.orc.impl.SerializationUtils
-
Parse a date from a string.
- parseDecimalFromString(String) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- parseDoubleFromString(String) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- parseFloatFromString(String) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- parseKeys(ParserUtils.StringPosition, TypeDescription) - Static method in class org.apache.orc.impl.ParserUtils
-
Annotate the given schema with the encryption information.
- parseLongFromString(String) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- parseMasks(ParserUtils.StringPosition, TypeDescription) - Static method in class org.apache.orc.impl.ParserUtils
-
Annotate the given schema with the masking information.
- parseName(ParserUtils.StringPosition) - Static method in class org.apache.orc.impl.ParserUtils
- ParserUtils - Class in org.apache.orc.impl
- ParserUtils() - Constructor for class org.apache.orc.impl.ParserUtils
- ParserUtils.StringPosition - Class in org.apache.orc.impl
- ParserUtils.TypeFinder - Class in org.apache.orc.impl
- ParserUtils.TypeVisitor - Interface in org.apache.orc.impl
- parseStripe(StripeInformation, boolean[]) - Method in class org.apache.orc.impl.reader.StripePlanner
-
Parse a new stripe.
- parseTime(String, boolean, boolean) - Static method in class org.apache.orc.impl.DateUtils
- parseType(ParserUtils.StringPosition) - Static method in class org.apache.orc.impl.ParserUtils
- PATCHED_BASE - Enum constant in enum class org.apache.orc.impl.RunLengthIntegerWriterV2.EncodingType
- path - Variable in class org.apache.orc.impl.ReaderImpl
- path - Variable in class org.apache.orc.impl.RecordReaderImpl
- percentileBits(long[], int, int, double) - Method in class org.apache.orc.impl.SerializationUtils
-
Compute the bits required to represent pth percentile value
- PhysicalFsWriter - Class in org.apache.orc.impl
- PhysicalFsWriter(FileSystem, Path, OrcFile.WriterOptions) - Constructor for class org.apache.orc.impl.PhysicalFsWriter
- PhysicalFsWriter(FileSystem, Path, OrcFile.WriterOptions, WriterEncryptionVariant[]) - Constructor for class org.apache.orc.impl.PhysicalFsWriter
- PhysicalFsWriter(FSDataOutputStream, OrcFile.WriterOptions, WriterEncryptionVariant[]) - Constructor for class org.apache.orc.impl.PhysicalFsWriter
- PhysicalFsWriter.VariantTracker - Class in org.apache.orc.impl
-
Record the information about each column encryption variant.
- physicalWriter(PhysicalWriter) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Change the physical writer of the ORC file.
- PhysicalWriter - Interface in org.apache.orc
-
This interface separates the physical layout of ORC files from the higher level details.
- PhysicalWriter.OutputReceiver - Interface in org.apache.orc
-
The target of an output stream.
- pickRowGroups() - Method in class org.apache.orc.impl.RecordReaderImpl
-
Pick the row groups that we need to load from the current stripe.
- pickRowGroups(StripeInformation, OrcProto.RowIndex[], OrcProto.Stream.Kind[], List<OrcProto.ColumnEncoding>, OrcProto.BloomFilterIndex[], boolean) - Method in class org.apache.orc.impl.RecordReaderImpl.SargApplier
-
Pick the row groups that we need to load from the current stripe.
- placeStreams(StreamName.Area, PhysicalFsWriter.SizeCounters) - Method in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
-
Place the streams in the appropriate area while updating the sizes with the number of bytes in the area.
- PLUGIN_FILTER_ALLOWLIST - Enum constant in enum class org.apache.orc.OrcConf
- pluginAllowListFilters() - Method in class org.apache.orc.Reader.Options
- pluginAllowListFilters(String...) - Method in class org.apache.orc.Reader.Options
- PluginFilterService - Interface in org.apache.orc.filter
-
Service to determine Plugin filters to be used during read.
- plus(long, TemporalUnit) - Method in class org.threeten.extra.chrono.HybridDate
- plus(TemporalAmount) - Method in class org.threeten.extra.chrono.HybridDate
- position - Variable in class org.apache.orc.impl.InStream
- positionalEvolutionLevel(int) - Method in class org.apache.orc.Reader.Options
-
Set number of levels to force schema evolution to be positional instead of based on the column names.
- PositionedOutputStream - Class in org.apache.orc.impl
- PositionedOutputStream() - Constructor for class org.apache.orc.impl.PositionedOutputStream
- PositionProvider - Interface in org.apache.orc.impl
-
An interface used for seeking to a row index.
- PositionProviderImpl(OrcProto.RowIndexEntry) - Constructor for class org.apache.orc.impl.RecordReaderImpl.PositionProviderImpl
- PositionProviderImpl(OrcProto.RowIndexEntry, int) - Constructor for class org.apache.orc.impl.RecordReaderImpl.PositionProviderImpl
- PositionRecorder - Interface in org.apache.orc.impl
-
An interface for recording positions in a stream.
- precision - Variable in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- precision - Variable in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- preFooterWrite(OrcFile.WriterContext) - Method in interface org.apache.orc.OrcFile.WriterCallback
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.BinaryTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.BooleanTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.ByteTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.DateTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.Decimal64TreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.DecimalTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.DoubleTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.FloatTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.IntegerTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.ListTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.MapTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.StringBaseTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.StructTreeWriter
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.TimestampTreeWriter
- prepareStripe(int) - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Set up for the next stripe.
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.TreeWriterBase
- prepareStripe(int) - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- present - Variable in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- PRESTO - Enum constant in enum class org.apache.orc.OrcFile.WriterImplementation
- PRESTO_ORIGINAL - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- preStripeWrite(OrcFile.WriterContext) - Method in interface org.apache.orc.OrcFile.WriterCallback
- PrimitiveBatchReader - Class in org.apache.orc.impl.reader.tree
- PrimitiveBatchReader(TypeReader) - Constructor for class org.apache.orc.impl.reader.tree.PrimitiveBatchReader
- print(PrintStream, TypeDescription) - Static method in class org.apache.orc.TypeDescriptionPrettyPrint
- printDate(int, boolean) - Static method in class org.apache.orc.impl.DateUtils
- printHexBinary(byte[]) - Static method in class org.apache.orc.impl.mask.SHA256MaskFactory
- printTime(long, boolean, boolean) - Static method in class org.apache.orc.impl.DateUtils
- printToBuffer(StringBuilder) - Method in class org.apache.orc.TypeDescription
- PROLEPTIC_GREGORIAN - Enum constant in enum class org.apache.orc.OrcConf
- PROLEPTIC_GREGORIAN_DEFAULT - Enum constant in enum class org.apache.orc.OrcConf
- prolepticYear(Era, int) - Method in class org.threeten.extra.chrono.HybridChronology
- PROTOBUF_MESSAGE_MAX_LIMIT - Static variable in class org.apache.orc.impl.InStream
- putAll(BloomFilter.BitSet) - Method in class org.apache.orc.util.BloomFilter.BitSet
-
Combines the two BitArrays using bitwise OR.
- putBuffer(ByteBuffer) - Method in class org.apache.orc.impl.RecordReaderUtils.ByteBufferAllocatorPool
Q
- query(TemporalQuery<R>) - Method in class org.threeten.extra.chrono.HybridDate
R
- range(long, long) - Method in class org.apache.orc.Reader.Options
-
Set the range of bytes to read
- range(ChronoField) - Method in class org.threeten.extra.chrono.HybridChronology
- range(TemporalField) - Method in class org.threeten.extra.chrono.HybridDate
- rangeChrono(ChronoField) - Method in class org.threeten.extra.chrono.HybridDate
- RBTREE - Enum constant in enum class org.apache.orc.impl.Dictionary.IMPL
- read() - Method in class org.apache.orc.impl.InStream.CompressedStream
- read() - Method in class org.apache.orc.impl.InStream.UncompressedStream
- read(byte[], int, int) - Method in class org.apache.orc.impl.InStream.CompressedStream
- read(byte[], int, int) - Method in class org.apache.orc.impl.InStream.UncompressedStream
- READ_ALL_RGS - Static variable in class org.apache.orc.impl.RecordReaderImpl.SargApplier
- READ_NO_RGS - Static variable in class org.apache.orc.impl.RecordReaderImpl.SargApplier
- readAll(InputStream) - Method in class org.apache.orc.impl.DynamicByteArray
-
Read the entire stream into this array.
- readBigInteger(InputStream) - Static method in class org.apache.orc.impl.SerializationUtils
-
Read the signed arbitrary sized BigInteger BigInteger in vint format
- readData(OrcIndex, boolean[], boolean, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.StripePlanner
-
Read the stripe data from the file.
- readDouble(InputStream) - Method in class org.apache.orc.impl.SerializationUtils
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.BooleanTreeReader
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.ByteTreeReader
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- reader - Variable in class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- Reader - Interface in org.apache.orc
-
The interface for reading ORC files.
- READER_USE_SELECTED - Enum constant in enum class org.apache.orc.OrcConf
- Reader.Options - Class in org.apache.orc
-
Options for creating a RecordReader.
- readerCategory - Variable in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- ReaderContext() - Constructor for class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- ReaderEncryption - Class in org.apache.orc.impl.reader
- ReaderEncryption() - Constructor for class org.apache.orc.impl.reader.ReaderEncryption
- ReaderEncryption(OrcProto.Footer, TypeDescription, long, BufferChunk, List<StripeInformation>, KeyProvider, Configuration) - Constructor for class org.apache.orc.impl.reader.ReaderEncryption
- ReaderEncryptionKey - Class in org.apache.orc.impl.reader
-
This tracks the keys for reading encrypted columns.
- ReaderEncryptionKey(OrcProto.EncryptionKey) - Constructor for class org.apache.orc.impl.reader.ReaderEncryptionKey
- ReaderEncryptionKey.State - Enum Class in org.apache.orc.impl.reader
-
Store the state of whether we've tried to decrypt a local key using this key or not.
- ReaderEncryptionVariant - Class in org.apache.orc.impl.reader
-
Information about an encrypted column.
- ReaderImpl - Class in org.apache.orc.impl
- ReaderImpl(Path, OrcFile.ReaderOptions) - Constructor for class org.apache.orc.impl.ReaderImpl
-
Constructor that let's the user specify additional options.
- ReaderImpl.StripeInformationImpl - Class in org.apache.orc.impl
- readerOptions(Configuration) - Static method in class org.apache.orc.OrcFile
- ReaderOptions(Configuration) - Constructor for class org.apache.orc.OrcFile.ReaderOptions
- readerType - Variable in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromAnyIntegerTreeReader
- readFileData(BufferChunkList, boolean) - Method in interface org.apache.orc.DataReader
-
Reads the data from the file.
- readFloat(InputStream) - Method in class org.apache.orc.impl.SerializationUtils
- readFollowData(OrcIndex, boolean[], int, boolean) - Method in class org.apache.orc.impl.reader.StripePlanner
- readInts(long[], int, int, int, InStream) - Method in class org.apache.orc.impl.SerializationUtils
-
Read bitpacked integers from input stream
- readLongLE(InputStream) - Method in class org.apache.orc.impl.SerializationUtils
- readOrcByteArrays(InStream, IntegerReader, LongColumnVector, BytesColumnVector, int) - Static method in class org.apache.orc.impl.TreeReaderFactory.BytesColumnVectorUtil
- readRowIndex(boolean[], OrcIndex) - Method in class org.apache.orc.impl.reader.StripePlanner
-
Read and parse the indexes for the current stripe.
- readRowIndex(int, boolean[], boolean[]) - Method in class org.apache.orc.impl.RecordReaderImpl
- readStripeFooter(StripeInformation) - Method in interface org.apache.orc.DataReader
- readStripeFooter(StripeInformation) - Method in class org.apache.orc.impl.RecordReaderImpl
- readTimestamp(TimestampColumnVector, int) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- readVslong(InputStream) - Static method in class org.apache.orc.impl.SerializationUtils
- readVulong(InputStream) - Static method in class org.apache.orc.impl.SerializationUtils
- RecordReader - Interface in org.apache.orc
-
A row-by-row iterator for ORC files.
- RecordReaderImpl - Class in org.apache.orc.impl
- RecordReaderImpl(ReaderImpl, Reader.Options) - Constructor for class org.apache.orc.impl.RecordReaderImpl
- RecordReaderImpl.PositionProviderImpl - Class in org.apache.orc.impl
- RecordReaderImpl.SargApplier - Class in org.apache.orc.impl
- RecordReaderImpl.ZeroPositionProvider - Class in org.apache.orc.impl
- RecordReaderUtils - Class in org.apache.orc.impl
-
Stateless methods shared between RecordReaderImpl and EncodedReaderImpl.
- RecordReaderUtils() - Constructor for class org.apache.orc.impl.RecordReaderUtils
- RecordReaderUtils.ByteBufferAllocatorPool - Class in org.apache.orc.impl
- REDACT - Enum constant in enum class org.apache.orc.DataMask.Standard
- RedactMaskFactory - Class in org.apache.orc.impl.mask
-
Masking strategy that hides most string and numeric values based on unicode character categories.
- RedactMaskFactory(String...) - Constructor for class org.apache.orc.impl.mask.RedactMaskFactory
- releaseAllBuffers() - Method in interface org.apache.orc.DataReader
-
Releases all buffers created by readFileData.
- releaseBuffer(ByteBuffer) - Method in interface org.apache.orc.DataReader
-
Deprecated.Use
DataReader.releaseAllBuffers()
instead. This method was incorrectly used by upper level code and shouldn't be used anymore. - removeAttribute(String) - Method in class org.apache.orc.TypeDescription
-
Remove attribute on this type, if it is set.
- removeWriter(Path) - Method in class org.apache.orc.impl.MemoryManagerImpl
-
Remove the given writer from the pool.
- removeWriter(Path) - Method in interface org.apache.orc.MemoryManager
-
Remove the given writer from the pool.
- rename(Path, Path) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- reset() - Method in interface org.apache.orc.CompressionCodec
-
Resets the codec, preparing it for reuse.
- reset() - Method in class org.apache.orc.impl.AircompressorCodec
- reset() - Method in class org.apache.orc.impl.BrotliCodec
- reset() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- reset() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- reset() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- reset() - Method in class org.apache.orc.impl.OrcFilterContextImpl
- reset() - Method in class org.apache.orc.impl.SnappyCodec
- reset() - Method in class org.apache.orc.impl.ZlibCodec
- reset() - Method in class org.apache.orc.impl.ZstdCodec
- reset() - Method in class org.apache.orc.util.BloomFilter
- reset(DiskRangeList) - Method in class org.apache.orc.impl.InStream
-
Reset the input to a new set of data.
- reset(DiskRangeList, long) - Method in class org.apache.orc.impl.InStream
-
Reset the input to a new set of data with a different length.
- resetBatch(VectorizedRowBatch, int) - Method in class org.apache.orc.impl.reader.tree.BatchReader
- resolveDate(Map<TemporalField, Long>, ResolverStyle) - Method in class org.threeten.extra.chrono.HybridChronology
- returnCodec(CompressionKind, CompressionCodec) - Static method in class org.apache.orc.impl.OrcCodecPool
-
Returns the codec to the pool or closes it, suppressing exceptions.
- root - Variable in class org.apache.orc.impl.StringRedBlackTree
- rootType - Variable in class org.apache.orc.impl.reader.tree.BatchReader
- ROW_BATCH_CHILD_LIMIT - Enum constant in enum class org.apache.orc.OrcConf
- ROW_BATCH_SIZE - Enum constant in enum class org.apache.orc.OrcConf
- ROW_INDEX_STRIDE - Enum constant in enum class org.apache.orc.OrcConf
- ROW_INDEX_STRIDE_DICTIONARY_CHECK - Enum constant in enum class org.apache.orc.OrcConf
- rowBatchSize(int) - Method in class org.apache.orc.Reader.Options
- rowIndexPosition - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- rowIndexStride - Variable in class org.apache.orc.impl.ReaderImpl
- rowIndexStride(int) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the distance between entries in the row index.
- rows - Variable in class org.apache.orc.impl.writer.StringBaseTreeWriter
- rows() - Method in class org.apache.orc.impl.ReaderImpl
- rows() - Method in interface org.apache.orc.Reader
-
Create a RecordReader that reads everything with the default options.
- rows(Reader.Options) - Method in class org.apache.orc.impl.ReaderImpl
- rows(Reader.Options) - Method in interface org.apache.orc.Reader
-
Create a RecordReader that uses the options given.
- ROWS_BETWEEN_CHECKS - Enum constant in enum class org.apache.orc.OrcConf
- RunLengthByteReader - Class in org.apache.orc.impl
-
A reader that reads a sequence of bytes.
- RunLengthByteReader(InStream) - Constructor for class org.apache.orc.impl.RunLengthByteReader
- RunLengthByteWriter - Class in org.apache.orc.impl
-
A streamFactory that writes a sequence of bytes.
- RunLengthByteWriter(PositionedOutputStream) - Constructor for class org.apache.orc.impl.RunLengthByteWriter
- RunLengthIntegerReader - Class in org.apache.orc.impl
-
A reader that reads a sequence of integers.
- RunLengthIntegerReader(InStream, boolean) - Constructor for class org.apache.orc.impl.RunLengthIntegerReader
- RunLengthIntegerReaderV2 - Class in org.apache.orc.impl
-
A reader that reads a sequence of light weight compressed integers.
- RunLengthIntegerReaderV2(InStream, boolean, boolean) - Constructor for class org.apache.orc.impl.RunLengthIntegerReaderV2
- RunLengthIntegerWriter - Class in org.apache.orc.impl
-
A streamFactory that writes a sequence of integers.
- RunLengthIntegerWriter(PositionedOutputStream, boolean) - Constructor for class org.apache.orc.impl.RunLengthIntegerWriter
- RunLengthIntegerWriterV2 - Class in org.apache.orc.impl
-
A writer that performs light weight compression over sequence of integers.
- RunLengthIntegerWriterV2(PositionedOutputStream, boolean, boolean) - Constructor for class org.apache.orc.impl.RunLengthIntegerWriterV2
- RunLengthIntegerWriterV2.EncodingType - Enum Class in org.apache.orc.impl
S
- SARG_COLUMNS - Enum constant in enum class org.apache.orc.OrcConf
- SargApplier(SearchArgument, long, SchemaEvolution, OrcFile.WriterVersion, boolean) - Constructor for class org.apache.orc.impl.RecordReaderImpl.SargApplier
-
Deprecated.Use the constructor having full parameters. This exists for backward compatibility.
- SargApplier(SearchArgument, long, SchemaEvolution, OrcFile.WriterVersion, boolean, boolean, boolean) - Constructor for class org.apache.orc.impl.RecordReaderImpl.SargApplier
- scale - Variable in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- scale - Variable in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- scaleReader - Variable in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- schema - Variable in class org.apache.orc.impl.RecordReaderImpl
- schema - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- schema - Variable in class org.apache.orc.StripeStatistics
- schema(TypeDescription) - Method in class org.apache.orc.Reader.Options
-
Set the schema on read type description.
- SchemaEvolution - Class in org.apache.orc.impl
-
Infer and track the evolution between the schema as stored in the file and the schema that has been requested by the reader.
- SchemaEvolution(TypeDescription, boolean[]) - Constructor for class org.apache.orc.impl.SchemaEvolution
-
Deprecated.
- SchemaEvolution(TypeDescription, TypeDescription, boolean[]) - Constructor for class org.apache.orc.impl.SchemaEvolution
-
Deprecated.
- SchemaEvolution(TypeDescription, TypeDescription, Reader.Options) - Constructor for class org.apache.orc.impl.SchemaEvolution
- SchemaEvolution.IllegalEvolutionException - Exception in org.apache.orc.impl
- scratchlcv - Variable in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- SCRITCHLEY_GO - Enum constant in enum class org.apache.orc.OrcFile.WriterImplementation
- SCRITCHLEY_GO_ORIGINAL - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- searchArgument(SearchArgument, String[]) - Method in class org.apache.orc.Reader.Options
-
Set search argument for predicate push down.
- seek(long) - Method in class org.apache.orc.impl.InStream.UncompressedStream
- seek(PositionProvider) - Method in class org.apache.orc.impl.BitFieldReader
- seek(PositionProvider) - Method in class org.apache.orc.impl.InStream.CompressedStream
- seek(PositionProvider) - Method in class org.apache.orc.impl.InStream
- seek(PositionProvider) - Method in class org.apache.orc.impl.InStream.UncompressedStream
- seek(PositionProvider) - Method in interface org.apache.orc.impl.IntegerReader
-
Seek to the position provided by index.
- seek(PositionProvider) - Method in class org.apache.orc.impl.RunLengthByteReader
- seek(PositionProvider) - Method in class org.apache.orc.impl.RunLengthIntegerReader
- seek(PositionProvider) - Method in class org.apache.orc.impl.RunLengthIntegerReaderV2
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.BatchReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.PrimitiveBatchReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.StructBatchReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BooleanTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ByteTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DoubleTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.FloatTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.NullTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
-
Seek to the given position.
- seek(PositionProvider[], TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BooleanTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ByteTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DoubleTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.FloatTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.NullTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- seek(PositionProvider, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- seekToRow(long) - Method in class org.apache.orc.impl.RecordReaderImpl
- seekToRow(long) - Method in interface org.apache.orc.RecordReader
-
Seek to a particular row number.
- Selected - Class in org.apache.orc.impl.filter
-
Wrapper class for the selected vector that centralizes the convenience functions
- SerializationUtils - Class in org.apache.orc.impl
- SerializationUtils() - Constructor for class org.apache.orc.impl.SerializationUtils
- SerializationUtils.FixedBitSizes - Enum Class in org.apache.orc.impl
- serialize() - Method in class org.apache.orc.impl.AcidStats
- serialize() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- serialize() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- serialize() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- serialize(OrcProto.BloomFilter.Builder, BloomFilter) - Static method in class org.apache.orc.util.BloomFilterIO
-
Serialize the BloomFilter to the ORC file.
- set(int) - Method in class org.apache.orc.util.BloomFilter.BitSet
-
Sets the bit at specified index.
- set(int, byte) - Method in class org.apache.orc.impl.DynamicByteArray
- set(int, int) - Method in class org.apache.orc.impl.DynamicIntArray
- setAttribute(String, String) - Method in class org.apache.orc.TypeDescription
-
Set an attribute on this type.
- setBatch(VectorizedRowBatch) - Method in class org.apache.orc.impl.OrcFilterContextImpl
- setBoolean(Configuration, boolean) - Method in enum class org.apache.orc.OrcConf
- setByteBuffer(ByteBuffer, int, int) - Method in class org.apache.orc.impl.DynamicByteArray
- setChunk(ByteBuffer) - Method in class org.apache.orc.impl.BufferChunk
- setCompressionZstdLevel(int) - Method in class org.apache.orc.OrcFile.ZstdCompressOptions
- setCompressionZstdWindowLog(int) - Method in class org.apache.orc.OrcFile.ZstdCompressOptions
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromDecimalTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromDoubleTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromStringGroupTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.AnyIntegerFromTimestampTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
-
Override this to use convertVector.
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DateFromStringGroupTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DateFromTimestampTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromAnyIntegerTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromDecimalTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromDoubleTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromStringGroupTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DecimalFromTimestampTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromAnyIntegerTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromDecimalTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromStringGroupTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.DoubleFromTimestampTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromAnyIntegerTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromBinaryTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromBooleanTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromDateTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromDecimalTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromDoubleTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.StringGroupFromTimestampTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromAnyIntegerTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromDateTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromDecimalTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromDoubleTreeReader
- setConvertVectorElement(int) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.TimestampFromStringGroupTreeReader
- setCurrent(DiskRangeList, boolean) - Method in class org.apache.orc.impl.InStream.CompressedStream
- setCurrent(DiskRangeList, boolean) - Method in class org.apache.orc.impl.InStream.EncryptedStream
- setCurrent(DiskRangeList, boolean) - Method in class org.apache.orc.impl.InStream
-
Set the current range
- setCurrent(DiskRangeList, boolean) - Method in class org.apache.orc.impl.InStream.UncompressedStream
- setData(CompressionCodec.DataKind) - Method in interface org.apache.orc.CompressionCodec.Options
-
Set the kind of data for the compression.
- setDouble(Configuration, double) - Method in enum class org.apache.orc.OrcConf
- setEncoding(int, WriterEncryptionVariant, OrcProto.ColumnEncoding) - Method in interface org.apache.orc.impl.writer.WriterContext
-
Set the encoding for the current stripe.
- setEncryption(ReaderEncryption) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- setFailure() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- setFilterCallback(Set<Integer>, Consumer<OrcFilterContext>) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- setFilterContext(boolean, int[], int) - Method in class org.apache.orc.impl.OrcFilterContextImpl
- setId(int) - Method in class org.apache.orc.impl.MaskDescriptionImpl
- setId(int) - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- setId(int) - Method in class org.apache.orc.impl.writer.WriterEncryptionVariant
- setInStream(InStream) - Method in class org.apache.orc.impl.RunLengthByteReader
- setInt(Configuration, int) - Method in enum class org.apache.orc.OrcConf
- setKeyProvider(KeyProvider) - Method in class org.apache.orc.OrcFile.ReaderOptions
-
Set the KeyProvider to override the default for getting keys.
- setKeyProvider(KeyProvider) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the key provider for column encryption.
- setKeyVersion(String, int, EncryptionAlgorithm) - Method in class org.apache.orc.OrcFile.WriterOptions
-
For users that need to override the current version of a key, this method allows them to define the version and algorithm for a given key.
- setLong(Configuration, long) - Method in enum class org.apache.orc.OrcConf
- setNull() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- setPosition(int) - Method in class org.apache.orc.impl.VisitorContextImpl
- setProlepticGregorian(boolean) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Should the writer use the proleptic Gregorian calendar for times and dates.
- setProlepticGregorian(boolean, boolean) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- setRowFilter(String[], Consumer<OrcFilterContext>) - Method in class org.apache.orc.Reader.Options
-
Set a row level filter.
- setRowGroupIndex(OrcProto.RowIndex[]) - Method in class org.apache.orc.impl.OrcIndex
- setRowIndexCols(boolean[]) - Method in class org.apache.orc.impl.RecordReaderImpl.SargApplier
- setSchema(TypeDescription) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the schema for the file.
- setSchemaEvolution(SchemaEvolution) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- setSelected(int[]) - Method in class org.apache.orc.impl.OrcFilterContextImpl
- setSelectedInUse(boolean) - Method in class org.apache.orc.impl.OrcFilterContextImpl
- setSelectedSize(int) - Method in class org.apache.orc.impl.OrcFilterContextImpl
- setShims(HadoopShims) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the HadoopShims to use.
- setSpeed(CompressionCodec.SpeedModifier) - Method in interface org.apache.orc.CompressionCodec.Options
-
Set the speed for the compression.
- setString(Configuration, String) - Method in enum class org.apache.orc.OrcConf
- setSuccess() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- setText(Text, int, int) - Method in class org.apache.orc.impl.DynamicByteArray
-
Set a text value from the bytes in this dynamic array.
- setVectorColumnCount(int) - Method in class org.apache.orc.impl.reader.tree.BatchReader
- setWorkingDirectory(Path) - Method in class org.apache.orc.util.StreamWrapperFileSystem
- SEVEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- SEVENTEEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- SHA256 - Enum constant in enum class org.apache.orc.DataMask.Standard
- SHA256MaskFactory - Class in org.apache.orc.impl.mask
-
Masking strategy that masks String, Varchar, Char and Binary types as SHA 256 hash.
- SHORT - Enum constant in enum class org.apache.orc.TypeDescription.Category
- SHORT_REPEAT - Enum constant in enum class org.apache.orc.impl.RunLengthIntegerWriterV2.EncodingType
- ShortTreeReader(int, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- shouldProcessChild(TypeReader, TypeReader.ReadPhase) - Static method in interface org.apache.orc.impl.reader.tree.TypeReader
-
Determines if the child of the parent should be allowed based on the read level.
- SIX - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- SIXTEEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- SIXTYFOUR - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- size - Variable in class org.apache.orc.impl.StringRedBlackTree
- size() - Method in interface org.apache.orc.impl.Dictionary
- size() - Method in class org.apache.orc.impl.DynamicByteArray
-
Get the size of the array.
- size() - Method in class org.apache.orc.impl.DynamicIntArray
- size() - Method in class org.apache.orc.impl.StringRedBlackTree
-
Get the number of elements in the set.
- size() - Method in class org.apache.orc.impl.StringHashTableDictionary
- sizeInBytes() - Method in class org.apache.orc.util.BloomFilter
- skip(long) - Method in class org.apache.orc.impl.BitFieldReader
- skip(long) - Method in interface org.apache.orc.impl.IntegerReader
-
Skip number of specified rows.
- skip(long) - Method in class org.apache.orc.impl.RunLengthByteReader
- skip(long) - Method in class org.apache.orc.impl.RunLengthIntegerReader
- skip(long) - Method in class org.apache.orc.impl.RunLengthIntegerReaderV2
- skip(InputStream, long) - Static method in class org.apache.orc.impl.IOUtils
-
Skips bytes from an input byte stream.
- SKIP_CORRUPT_DATA - Enum constant in enum class org.apache.orc.OrcConf
- skipCorrupt - Variable in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- skipCorrupt(boolean) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- skipCorruptRecords(boolean) - Method in class org.apache.orc.Reader.Options
-
Set whether to skip corrupt records.
- skipDouble(InputStream, int) - Method in class org.apache.orc.impl.SerializationUtils
- skipFloat(InputStream, int) - Method in class org.apache.orc.impl.SerializationUtils
- skipFully(InputStream, long) - Static method in class org.apache.orc.impl.IOUtils
-
Skips the requested number of bytes or fail if there are not enough left.
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.BatchReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.PrimitiveBatchReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.StructBatchReader
- skipRows(long, TypeReader.ReadPhase) - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BooleanTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ByteTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DoubleTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.FloatTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.NullTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- skipRows(long, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- sliceAndShift(long, long, long) - Method in class org.apache.orc.impl.BufferChunk
- SNAPPY - Enum constant in enum class org.apache.orc.CompressionKind
- SnappyCodec - Class in org.apache.orc.impl
- sortRoots() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- SPEED - Enum constant in enum class org.apache.orc.OrcFile.CompressionStrategy
- SPEED - Enum constant in enum class org.apache.orc.OrcFile.EncodingStrategy
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.ConvertTreeReaderFactory.ConvertTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.BatchReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.PrimitiveBatchReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.reader.tree.StructBatchReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in interface org.apache.orc.impl.reader.tree.TypeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.BooleanTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ByteTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DateTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.DoubleTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.FloatTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.IntTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ListTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.LongTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.NullTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.ShortTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.TreeReader
- startStripe(StripePlanner, TypeReader.ReadPhase) - Method in class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- stream - Variable in class org.apache.orc.impl.TreeReaderFactory.BinaryTreeReader
- stream - Variable in class org.apache.orc.impl.TreeReaderFactory.DoubleTreeReader
- stream - Variable in class org.apache.orc.impl.TreeReaderFactory.FloatTreeReader
- stream - Variable in class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- StreamInformation(OrcProto.Stream.Kind, int, long, long) - Constructor for class org.apache.orc.impl.reader.StripePlanner.StreamInformation
- StreamName - Class in org.apache.orc.impl
-
The name of a stream within a stripe.
- StreamName(int, OrcProto.Stream.Kind) - Constructor for class org.apache.orc.impl.StreamName
- StreamName(int, OrcProto.Stream.Kind, EncryptionVariant) - Constructor for class org.apache.orc.impl.StreamName
- StreamName.Area - Enum Class in org.apache.orc.impl
- StreamOptions - Class in org.apache.orc.impl.writer
-
The compression and encryption options for writing a stream.
- StreamOptions() - Constructor for class org.apache.orc.impl.InStream.StreamOptions
- StreamOptions(int) - Constructor for class org.apache.orc.impl.writer.StreamOptions
-
An option object with the given buffer size set.
- StreamOptions(InStream.StreamOptions) - Constructor for class org.apache.orc.impl.InStream.StreamOptions
- StreamOptions(StreamOptions) - Constructor for class org.apache.orc.impl.writer.StreamOptions
- streams - Variable in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
- StreamWrapperFileSystem - Class in org.apache.orc.util
-
This class provides an adaptor so that tools that want to read an ORC file from an FSDataInputStream can do so.
- StreamWrapperFileSystem(FSDataInputStream, FileStatus, Configuration) - Constructor for class org.apache.orc.util.StreamWrapperFileSystem
-
Create a FileSystem that only has information about the given stream.
- StreamWrapperFileSystem(FSDataInputStream, Path, long, Configuration) - Constructor for class org.apache.orc.util.StreamWrapperFileSystem
-
Create a FileSystem that only has information about the given stream.
- STRING - Enum constant in enum class org.apache.orc.TypeDescription.Category
- StringBaseTreeWriter - Class in org.apache.orc.impl.writer
- StringColumnStatistics - Interface in org.apache.orc
-
Statistics for string columns.
- StringDictionaryTreeReader(int, InStream, InStream, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.StringDictionaryTreeReader
- StringDirectTreeReader(int, InStream, InStream, InStream, OrcProto.ColumnEncoding.Kind, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.StringDirectTreeReader
- StringHashTableDictionary - Class in org.apache.orc.impl
-
Using HashTable to represent a dictionary.
- StringHashTableDictionary(int) - Constructor for class org.apache.orc.impl.StringHashTableDictionary
- StringHashTableDictionary(int, float) - Constructor for class org.apache.orc.impl.StringHashTableDictionary
- stringifyDiskRanges(DiskRangeList) - Static method in class org.apache.orc.impl.RecordReaderUtils
-
Build a string representation of a list of disk ranges.
- StringPosition(String) - Constructor for class org.apache.orc.impl.ParserUtils.StringPosition
- StringRedBlackTree - Class in org.apache.orc.impl
-
A red-black tree that stores strings.
- StringRedBlackTree(int) - Constructor for class org.apache.orc.impl.StringRedBlackTree
- StringTreeReader(int, InStream, InStream, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.StringTreeReader
- StringTreeWriter - Class in org.apache.orc.impl.writer
- STRIPE_ROW_COUNT - Enum constant in enum class org.apache.orc.OrcConf
- STRIPE_SIZE - Enum constant in enum class org.apache.orc.OrcConf
- stripeColStatistics - Variable in class org.apache.orc.impl.writer.TreeWriterBase
- StripeInformation - Interface in org.apache.orc
-
Information about the stripes in an ORC file that is provided by the Reader.
- StripeInformationImpl(OrcProto.StripeInformation, long, long, byte[][]) - Constructor for class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- StripePlanner - Class in org.apache.orc.impl.reader
-
This class handles parsing the stripe information and handling the necessary filtering and selection.
- StripePlanner(StripePlanner) - Constructor for class org.apache.orc.impl.reader.StripePlanner
- StripePlanner(TypeDescription, ReaderEncryption, DataReader, OrcFile.WriterVersion, boolean, long) - Constructor for class org.apache.orc.impl.reader.StripePlanner
- StripePlanner(TypeDescription, ReaderEncryption, DataReader, OrcFile.WriterVersion, boolean, long, Set<Integer>) - Constructor for class org.apache.orc.impl.reader.StripePlanner
-
Create a stripe parser.
- StripePlanner.StreamInformation - Class in org.apache.orc.impl.reader
- stripeSize(long) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Set the stripe size for the file.
- stripeStatistics - Variable in class org.apache.orc.impl.ReaderImpl
- StripeStatistics - Class in org.apache.orc
-
The statistics for a stripe.
- StripeStatistics(List<OrcProto.ColumnStatistics>) - Constructor for class org.apache.orc.StripeStatistics
- StripeStatistics(TypeDescription, List<OrcProto.ColumnStatistics>, boolean, boolean) - Constructor for class org.apache.orc.StripeStatistics
- StripeStatisticsImpl - Class in org.apache.orc.impl
- StripeStatisticsImpl(TypeDescription, boolean, boolean) - Constructor for class org.apache.orc.impl.StripeStatisticsImpl
- StripeStatisticsImpl(TypeDescription, List<OrcProto.ColumnStatistics>, boolean, boolean) - Constructor for class org.apache.orc.impl.StripeStatisticsImpl
- stripeStats - Variable in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
- stripeStatsStreams - Variable in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
- STRUCT - Enum constant in enum class org.apache.orc.TypeDescription.Category
- StructBatchReader - Class in org.apache.orc.impl.reader.tree
-
Handles the Struct rootType for batch handling.
- StructBatchReader(TypeReader, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.reader.tree.StructBatchReader
- StructIdentity - Class in org.apache.orc.impl.mask
-
A data mask for struct types that applies the given masks to its children, but doesn't mask at this level.
- StructTreeReader(int, InStream, TreeReaderFactory.Context, OrcProto.ColumnEncoding, TypeReader[]) - Constructor for class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- StructTreeReader(int, TypeDescription, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.StructTreeReader
- StructTreeWriter - Class in org.apache.orc.impl.writer
- StructTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext) - Constructor for class org.apache.orc.impl.writer.StructTreeWriter
- SUCCESS - Enum constant in enum class org.apache.orc.impl.reader.ReaderEncryptionKey.State
- SUPPORTS_AES_256 - Static variable in class org.apache.orc.InMemoryKeystore
-
Support AES 256 ?
- suppress() - Method in class org.apache.orc.impl.OutStream
-
Set suppress flag
- suppress() - Method in interface org.apache.orc.PhysicalWriter.OutputReceiver
-
Suppress this stream from being written to the stripe.
T
- tags - Variable in class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- tail - Variable in class org.apache.orc.impl.ReaderImpl
- takeFile() - Method in class org.apache.orc.impl.ReaderImpl
-
Take the file from the reader.
- TEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- test(byte[]) - Method in class org.apache.orc.util.BloomFilter
- testBytes(byte[], int, int) - Method in class org.apache.orc.util.BloomFilter
- testDouble(double) - Method in class org.apache.orc.util.BloomFilter
- testLong(long) - Method in class org.apache.orc.util.BloomFilter
- testString(String) - Method in class org.apache.orc.util.BloomFilter
- testString(String) - Method in class org.apache.orc.util.BloomFilterUtf8
- TEXT - Enum constant in enum class org.apache.orc.CompressionCodec.DataKind
- THIRTEEN - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- THIRTY - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- THIRTYTWO - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- THREE - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TIMESTAMP - Enum constant in enum class org.apache.orc.TypeDescription.Category
- TIMESTAMP_INSTANT - Enum constant in enum class org.apache.orc.TypeDescription.Category
- TimestampColumnStatistics - Interface in org.apache.orc
-
Statistics for Timestamp columns.
- TimestampTreeReader(int, InStream, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context, boolean) - Constructor for class org.apache.orc.impl.TreeReaderFactory.TimestampTreeReader
- TimestampTreeWriter - Class in org.apache.orc.impl.writer
- TimestampTreeWriter(TypeDescription, WriterEncryptionVariant, WriterContext, boolean) - Constructor for class org.apache.orc.impl.writer.TimestampTreeWriter
- toEpochDay() - Method in class org.threeten.extra.chrono.HybridDate
- toJson() - Method in class org.apache.orc.TypeDescription
- TOLERATE_MISSING_SCHEMA - Enum constant in enum class org.apache.orc.OrcConf
- tolerateMissingSchema(boolean) - Method in class org.apache.orc.Reader.Options
-
Set whether to make a best effort to tolerate schema evolution for files which do not have an embedded schema because they were written with a' pre-HIVE-4243 writer.
- toString() - Method in class org.apache.orc.impl.AcidStats
- toString() - Method in class org.apache.orc.impl.BitFieldReader
- toString() - Method in class org.apache.orc.impl.BufferChunk
- toString() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- toString() - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- toString() - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- toString() - Method in class org.apache.orc.impl.DynamicByteArray
- toString() - Method in class org.apache.orc.impl.DynamicIntArray
- toString() - Method in class org.apache.orc.impl.InStream.CompressedStream
- toString() - Method in class org.apache.orc.impl.InStream.EncryptedStream
- toString() - Method in class org.apache.orc.impl.InStream.StreamOptions
- toString() - Method in class org.apache.orc.impl.InStream
- toString() - Method in class org.apache.orc.impl.InStream.UncompressedStream
- toString() - Method in class org.apache.orc.impl.MaskDescriptionImpl
- toString() - Method in class org.apache.orc.impl.OutStream
- toString() - Method in class org.apache.orc.impl.ParserUtils.StringPosition
- toString() - Method in class org.apache.orc.impl.PhysicalFsWriter
- toString() - Method in class org.apache.orc.impl.reader.ReaderEncryptionKey
- toString() - Method in class org.apache.orc.impl.ReaderImpl.StripeInformationImpl
- toString() - Method in class org.apache.orc.impl.ReaderImpl
- toString() - Method in class org.apache.orc.impl.RunLengthByteReader
- toString() - Method in class org.apache.orc.impl.StreamName
- toString() - Method in class org.apache.orc.impl.writer.StreamOptions
- toString() - Method in class org.apache.orc.impl.writer.WriterEncryptionKey
- toString() - Method in enum class org.apache.orc.OrcFile.BloomFilterVersion
- toString() - Method in class org.apache.orc.Reader.Options
- toString() - Method in class org.apache.orc.TypeDescription
- toString() - Method in class org.apache.orc.util.BloomFilter
- toString() - Method in class org.threeten.extra.chrono.HybridDate
- TreeReader(int, InStream, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.TreeReader
- TreeReaderFactory - Class in org.apache.orc.impl
-
Factory for creating ORC tree readers.
- TreeReaderFactory() - Constructor for class org.apache.orc.impl.TreeReaderFactory
- TreeReaderFactory.BinaryTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.BooleanTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.BytesColumnVectorUtil - Class in org.apache.orc.impl
- TreeReaderFactory.ByteTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.CharTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.Context - Interface in org.apache.orc.impl
- TreeReaderFactory.DateTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.Decimal64TreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.DecimalTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.DoubleTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.FloatTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.IntTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.ListTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.LongTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.MapTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.NullTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.ReaderContext - Class in org.apache.orc.impl
- TreeReaderFactory.ShortTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.StringDictionaryTreeReader - Class in org.apache.orc.impl
-
A reader for string columns that are dictionary encoded in the current stripe.
- TreeReaderFactory.StringDirectTreeReader - Class in org.apache.orc.impl
-
A reader for string columns that are direct encoded in the current stripe.
- TreeReaderFactory.StringTreeReader - Class in org.apache.orc.impl
-
A tree reader that will read string columns.
- TreeReaderFactory.StructTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.TimestampTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.TreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.UnionTreeReader - Class in org.apache.orc.impl
- TreeReaderFactory.VarcharTreeReader - Class in org.apache.orc.impl
- TreeWriter - Interface in org.apache.orc.impl.writer
-
The writers for the specific writers of each type.
- TreeWriter.Factory - Class in org.apache.orc.impl.writer
- TreeWriterBase - Class in org.apache.orc.impl.writer
-
The parent class of all of the writers for each column.
- TRINO - Enum constant in enum class org.apache.orc.OrcFile.WriterImplementation
- TRINO_ORIGINAL - Enum constant in enum class org.apache.orc.OrcFile.WriterVersion
- truncateBytesTo(int, byte[], int, int) - Static method in class org.apache.orc.impl.Utf8Utils
-
Return the number of bytes required to read at most maxLength characters in full from a utf-8 encoded byte array provided by data[offset:offset+length].
- TWELVE - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWENTY - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWENTYEIGHT - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWENTYFOUR - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWENTYONE - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWENTYSIX - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWENTYTHREE - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWENTYTWO - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TWO - Enum constant in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
- TypeDescription - Class in org.apache.orc
-
This is the description of the types in an ORC file.
- TypeDescription(TypeDescription.Category) - Constructor for class org.apache.orc.TypeDescription
- TypeDescription.Category - Enum Class in org.apache.orc
- TypeDescription.RowBatchVersion - Enum Class in org.apache.orc
-
Specify the version of the VectorizedRowBatch that the user desires.
- TypeDescriptionPrettyPrint - Class in org.apache.orc
-
A pretty printer for TypeDescription.
- TypeDescriptionPrettyPrint() - Constructor for class org.apache.orc.TypeDescriptionPrettyPrint
- TypeFinder(TypeDescription) - Constructor for class org.apache.orc.impl.ParserUtils.TypeFinder
- TypeReader - Interface in org.apache.orc.impl.reader.tree
- TypeReader.ReaderCategory - Enum Class in org.apache.orc.impl.reader.tree
- TypeReader.ReadPhase - Enum Class in org.apache.orc.impl.reader.tree
- types - Variable in class org.apache.orc.impl.ReaderImpl
- TypeUtils - Class in org.apache.orc.impl
U
- UncompressedStream(Object, long, long) - Constructor for class org.apache.orc.impl.InStream.UncompressedStream
-
Create the stream without calling reset on it.
- UncompressedStream(Object, DiskRangeList, long, long) - Constructor for class org.apache.orc.impl.InStream.UncompressedStream
- UNION - Enum constant in enum class org.apache.orc.TypeDescription.Category
- UnionIdentity - Class in org.apache.orc.impl.mask
-
A data mask for union types that applies the given masks to its children, but doesn't mask at this level.
- UnionTreeReader(int, InStream, TreeReaderFactory.Context, OrcProto.ColumnEncoding, TypeReader[]) - Constructor for class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- UnionTreeReader(int, TypeDescription, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.UnionTreeReader
- UnionTreeWriter - Class in org.apache.orc.impl.writer
- UNKNOWN - Enum constant in enum class org.apache.orc.OrcFile.WriterImplementation
- UnknownFormatException - Exception in org.apache.orc
-
Deprecated.This will be removed in the future releases.
- UnknownFormatException(Path, String, OrcProto.PostScript) - Constructor for exception org.apache.orc.UnknownFormatException
-
Deprecated.
- UNSTABLE_PRE_2_0 - Enum constant in enum class org.apache.orc.OrcFile.Version
-
Do not use this format except for testing.
- UnSupportedSArgException(String) - Constructor for exception org.apache.orc.impl.filter.FilterFactory.UnSupportedSArgException
- until(ChronoLocalDate) - Method in class org.threeten.extra.chrono.HybridDate
- until(Temporal, TemporalUnit) - Method in class org.threeten.extra.chrono.HybridDate
- UNTRIED - Enum constant in enum class org.apache.orc.impl.reader.ReaderEncryptionKey.State
- updateBinary(byte[], int, int, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- updateBinary(byte[], int, int, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateBinary(BytesWritable) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.BinaryStatisticsImpl
- updateBinary(BytesWritable) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateBoolean(boolean, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateByteCount(long) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateCollectionLength(long) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
-
Update the collection length for Map and List type.
- updateColumn(int, OrcProto.ColumnStatistics) - Method in class org.apache.orc.impl.StripeStatisticsImpl
- updateDate(int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateDate(DateWritable) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateDecimal(HiveDecimalWritable) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateDecimal64(long, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateDouble(double) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateInteger(long, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updates - Variable in class org.apache.orc.impl.AcidStats
- updateSelected(int) - Method in class org.apache.orc.impl.OrcFilterContextImpl
- updateString(byte[], int, int, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- updateString(byte[], int, int, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateString(Text) - Method in class org.apache.orc.impl.ColumnStatisticsImpl.StringStatisticsImpl
- updateString(Text) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateTimestamp(long, int) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- updateTimestamp(Timestamp) - Method in class org.apache.orc.impl.ColumnStatisticsImpl
- USE_DECIMAL64 - Enum constant in enum class org.apache.orc.TypeDescription.RowBatchVersion
- USE_ZEROCOPY - Enum constant in enum class org.apache.orc.OrcConf
- useDictionaryEncoding - Variable in class org.apache.orc.impl.writer.StringBaseTreeWriter
- useProlepticGregorian() - Method in interface org.apache.orc.impl.TreeReaderFactory.Context
- useProlepticGregorian() - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- useSelected() - Method in class org.apache.orc.Reader.Options
- useSelected(boolean) - Method in class org.apache.orc.Reader.Options
- useUTCTimestamp - Variable in class org.apache.orc.impl.ReaderImpl
- useUTCTimestamp(boolean) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- useUTCTimestamp(boolean) - Method in class org.apache.orc.OrcFile.ReaderOptions
- useUTCTimestamp(boolean) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Manually set the time zone for the writer to utc.
- useZeroCopy(boolean) - Method in class org.apache.orc.Reader.Options
-
Set whether to use zero copy from HDFS.
- UTF8 - Enum constant in enum class org.apache.orc.OrcFile.BloomFilterVersion
- UTF8_UTC - Enum constant in enum class org.apache.orc.util.BloomFilterIO.Encoding
- Utf8Utils - Class in org.apache.orc.impl
- Utf8Utils() - Constructor for class org.apache.orc.impl.Utf8Utils
V
- V_0_11 - Enum constant in enum class org.apache.orc.OrcFile.Version
- V_0_12 - Enum constant in enum class org.apache.orc.OrcFile.Version
- validateSelected() - Method in class org.apache.orc.impl.OrcFilterContextImpl
- valueOf(String) - Static method in enum class org.apache.orc.CompressionCodec.DataKind
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.CompressionCodec.SpeedModifier
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.CompressionKind
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.DataMask.Standard
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.impl.Dictionary.IMPL
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.impl.reader.ReaderEncryptionKey.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.impl.reader.tree.TypeReader.ReaderCategory
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.impl.RunLengthIntegerWriterV2.EncodingType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.impl.StreamName.Area
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.OrcConf
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.OrcFile.BloomFilterVersion
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.OrcFile.CompressionStrategy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.OrcFile.EncodingStrategy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.OrcFile.Version
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.OrcFile.WriterImplementation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.OrcFile.WriterVersion
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.TypeDescription.Category
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.TypeDescription.RowBatchVersion
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.orc.util.BloomFilterIO.Encoding
-
Returns the enum constant of this class with the specified name.
- valueReader - Variable in class org.apache.orc.impl.TreeReaderFactory.Decimal64TreeReader
- valueReader - Variable in class org.apache.orc.impl.TreeReaderFactory.MapTreeReader
- values() - Static method in enum class org.apache.orc.CompressionCodec.DataKind
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.CompressionCodec.SpeedModifier
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.CompressionKind
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.DataMask.Standard
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.impl.Dictionary.IMPL
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.impl.reader.ReaderEncryptionKey.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.impl.reader.tree.TypeReader.ReaderCategory
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.impl.reader.tree.TypeReader.ReadPhase
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.impl.RunLengthIntegerWriterV2.EncodingType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.impl.SerializationUtils.FixedBitSizes
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.impl.StreamName.Area
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.OrcConf
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.OrcFile.BloomFilterVersion
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.OrcFile.CompressionStrategy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.OrcFile.EncodingStrategy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.OrcFile.Version
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.OrcFile.WriterImplementation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.OrcFile.WriterVersion
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.TypeDescription.Category
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.TypeDescription.RowBatchVersion
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.orc.util.BloomFilterIO.Encoding
-
Returns an array containing the constants of this enum class, in the order they are declared.
- valueStream - Variable in class org.apache.orc.impl.TreeReaderFactory.DecimalTreeReader
- VARCHAR - Enum constant in enum class org.apache.orc.TypeDescription.Category
- VarcharTreeReader(int, int, InStream, InStream, InStream, InStream, OrcProto.ColumnEncoding, TreeReaderFactory.Context) - Constructor for class org.apache.orc.impl.TreeReaderFactory.VarcharTreeReader
- VarcharTreeWriter - Class in org.apache.orc.impl.writer
-
Under the covers, varchar is written to ORC the same way as string.
- vectorColumnCount - Variable in class org.apache.orc.impl.reader.tree.BatchReader
- VectorFilter - Interface in org.apache.orc.impl.filter
-
A filter that operates on the supplied
VectorizedRowBatch
and updates the selections. - version(OrcFile.Version) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Sets the version of the file that will be written.
- visit(Dictionary.Visitor) - Method in interface org.apache.orc.impl.Dictionary
-
Traverse the whole dictionary and apply the action.
- visit(Dictionary.Visitor) - Method in class org.apache.orc.impl.StringHashTableDictionary
- visit(Dictionary.Visitor) - Method in class org.apache.orc.impl.StringRedBlackTree
-
Visit all of the nodes in the tree in sorted order.
- visit(Dictionary.VisitorContext) - Method in interface org.apache.orc.impl.Dictionary.Visitor
-
Called once for each node of the tree in sort order.
- visit(TypeDescription, int) - Method in class org.apache.orc.impl.ParserUtils.TypeFinder
- visit(TypeDescription, int) - Method in interface org.apache.orc.impl.ParserUtils.TypeVisitor
-
As we navigate to the column, call this on each level
- VisitorContextImpl - Class in org.apache.orc.impl
-
Base implementation for
Dictionary.VisitorContext
used to traversing all nodes in a dictionary. - VisitorContextImpl(DynamicByteArray, DynamicIntArray) - Constructor for class org.apache.orc.impl.VisitorContextImpl
W
- with(TemporalAdjuster) - Method in class org.threeten.extra.chrono.HybridDate
- with(TemporalField, long) - Method in class org.threeten.extra.chrono.HybridDate
- withBufferSize(int) - Method in class org.apache.orc.impl.InStream.StreamOptions
- withCodec(CompressionCodec) - Method in class org.apache.orc.impl.InStream.StreamOptions
- withCodec(CompressionCodec, CompressionCodec.Options) - Method in class org.apache.orc.impl.writer.StreamOptions
-
Compress using the given codec.
- withCompression(InStream.StreamOptions) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withEncryption(EncryptionAlgorithm, Key) - Method in class org.apache.orc.impl.writer.StreamOptions
- withEncryption(EncryptionAlgorithm, Key, byte[]) - Method in class org.apache.orc.impl.InStream.StreamOptions
- withFile(FSDataInputStream) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withFileSystem(FileSystem) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withFileSystemSupplier(Supplier<FileSystem>) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withMaxDiskRangeChunkLimit(int) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withMaxLength(int) - Method in class org.apache.orc.TypeDescription
-
Set the maximum length for char and varchar types.
- withMinSeekSize(int) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withMinSeekSizeTolerance(double) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withPath(Path) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- withPrecision(int) - Method in class org.apache.orc.TypeDescription
-
For decimal types, set the precision.
- withScale(int) - Method in class org.apache.orc.TypeDescription
-
For decimal types, set the scale.
- withZeroCopy(boolean) - Method in class org.apache.orc.impl.DataReaderProperties.Builder
- write(byte) - Method in class org.apache.orc.impl.RunLengthByteWriter
- write(byte[], int, int) - Method in class org.apache.orc.impl.OutStream
- write(int) - Method in class org.apache.orc.impl.BitFieldWriter
- write(int) - Method in class org.apache.orc.impl.OutStream
- write(long) - Method in interface org.apache.orc.impl.IntegerWriter
-
Write the integer value
- write(long) - Method in class org.apache.orc.impl.RunLengthIntegerWriter
- write(long) - Method in class org.apache.orc.impl.RunLengthIntegerWriterV2
- write(OutputStream, int, int) - Method in class org.apache.orc.impl.DynamicByteArray
-
Write out a range of this dynamic array to an output stream.
- WRITE_FORMAT - Enum constant in enum class org.apache.orc.OrcConf
- WRITE_VARIABLE_LENGTH_BLOCKS - Enum constant in enum class org.apache.orc.OrcConf
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.BinaryTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.BooleanTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.ByteTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.CharTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.DateTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.Decimal64TreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.DecimalTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.DoubleTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.FloatTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.IntegerTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.ListTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.MapTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.StringTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.StructTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.TimestampTreeWriter
- writeBatch(ColumnVector, int, int) - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Write a ColumnVector to the file.
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.TreeWriterBase
-
Write the values from the given vector from offset for length elements.
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- writeBatch(ColumnVector, int, int) - Method in class org.apache.orc.impl.writer.VarcharTreeWriter
- writeBigInteger(OutputStream, BigInteger) - Static method in class org.apache.orc.impl.SerializationUtils
-
Write the arbitrarily sized signed BigInteger in vint format.
- writeBloomFilter(StreamName, OrcProto.BloomFilterIndex.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- writeBloomFilter(StreamName, OrcProto.BloomFilterIndex.Builder) - Method in interface org.apache.orc.impl.writer.WriterContext
- writeBloomFilter(StreamName, OrcProto.BloomFilterIndex.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Write a bloom filter index in the given stream name.
- writeBytes(OutputStream) - Method in interface org.apache.orc.impl.Dictionary.VisitorContext
-
Write the bytes for the string to the given output stream.
- writeBytes(OutputStream) - Method in class org.apache.orc.impl.VisitorContextImpl
- writeDouble(OutputStream, double) - Method in class org.apache.orc.impl.SerializationUtils
- writeFileFooter(OrcProto.Footer.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- writeFileFooter(OrcProto.Footer.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Writes out the file footer.
- writeFileMetadata(OrcProto.Metadata.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- writeFileMetadata(OrcProto.Metadata.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Writes out the file metadata.
- writeFileStatistics() - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- writeFileStatistics() - Method in class org.apache.orc.impl.writer.ListTreeWriter
- writeFileStatistics() - Method in class org.apache.orc.impl.writer.MapTreeWriter
- writeFileStatistics() - Method in class org.apache.orc.impl.writer.StructTreeWriter
- writeFileStatistics() - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Write the FileStatistics for each column in each encryption variant.
- writeFileStatistics() - Method in class org.apache.orc.impl.writer.TreeWriterBase
- writeFileStatistics() - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- writeFloat(OutputStream, float) - Method in class org.apache.orc.impl.SerializationUtils
- writeHeader() - Method in class org.apache.orc.impl.PhysicalFsWriter
- writeHeader() - Method in interface org.apache.orc.PhysicalWriter
-
Writes the header of the file, which consists of the magic "ORC" bytes.
- writeIndex(StreamName, OrcProto.RowIndex.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- writeIndex(StreamName, OrcProto.RowIndex.Builder) - Method in interface org.apache.orc.impl.writer.WriterContext
- writeIndex(StreamName, OrcProto.RowIndex.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Write an index in the given stream name.
- writeIntermediateFooter() - Method in class org.apache.orc.impl.WriterImpl
- writeIntermediateFooter() - Method in interface org.apache.orc.Writer
-
Write an intermediate footer on the file such that if the file is truncated to the returned offset, it would be a valid ORC file.
- writeInts(long[], int, int, int, OutputStream) - Method in class org.apache.orc.impl.SerializationUtils
-
Bitpack and write the input values to underlying output stream
- writePostScript(OrcProto.PostScript.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- writePostScript(OrcProto.PostScript.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Writes out the postscript (including the size byte if needed).
- Writer - Interface in org.apache.orc
-
The interface for writing ORC files.
- WriterContext - Interface in org.apache.orc.impl.writer
- WriterEncryptionKey - Class in org.apache.orc.impl.writer
- WriterEncryptionKey(HadoopShims.KeyMetadata) - Constructor for class org.apache.orc.impl.writer.WriterEncryptionKey
- WriterEncryptionVariant - Class in org.apache.orc.impl.writer
- WriterEncryptionVariant(WriterEncryptionKey, TypeDescription, LocalKey) - Constructor for class org.apache.orc.impl.writer.WriterEncryptionVariant
- WriterImpl - Class in org.apache.orc.impl
-
An ORC file writer.
- WriterImpl(FileSystem, Path, OrcFile.WriterOptions) - Constructor for class org.apache.orc.impl.WriterImpl
- WriterImplV2 - Class in org.apache.orc.impl.writer
-
An ORCv2 file writer.
- WriterImplV2(FileSystem, Path, OrcFile.WriterOptions) - Constructor for class org.apache.orc.impl.writer.WriterImplV2
- WriterInternal - Interface in org.apache.orc.impl
-
The ORC internal API to the writer.
- writeRootBatch(VectorizedRowBatch, int, int) - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- writeRootBatch(VectorizedRowBatch, int, int) - Method in class org.apache.orc.impl.writer.StructTreeWriter
- writeRootBatch(VectorizedRowBatch, int, int) - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Write a VectorizedRowBatch to the file.
- writeRootBatch(VectorizedRowBatch, int, int) - Method in class org.apache.orc.impl.writer.TreeWriterBase
-
Handle the top level object write.
- writerOptions(Properties, Configuration) - Static method in class org.apache.orc.OrcFile
-
Create a set of write options based on a set of table properties and configuration.
- writerOptions(Configuration) - Static method in class org.apache.orc.OrcFile
-
Create a set of writer options based on a configuration.
- WriterOptions(Properties, Configuration) - Constructor for class org.apache.orc.OrcFile.WriterOptions
- writerTimeZone(String) - Method in class org.apache.orc.impl.TreeReaderFactory.ReaderContext
- writerUsedProlepticGregorian() - Method in class org.apache.orc.impl.ReaderImpl
- writerUsedProlepticGregorian() - Method in interface org.apache.orc.Reader
-
Was the file written using the proleptic Gregorian calendar.
- writerVersion(OrcFile.WriterVersion) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Manually set the writer version.
- writeStatistics(StreamName, OrcProto.ColumnStatistics.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
- writeStatistics(StreamName, OrcProto.ColumnStatistics.Builder) - Method in interface org.apache.orc.impl.writer.WriterContext
-
Set the column statistics for the stripe or file.
- writeStatistics(StreamName, OrcProto.ColumnStatistics.Builder) - Method in interface org.apache.orc.PhysicalWriter
-
Write a stripe or file statistics to the file.
- writeStreams(StreamName.Area, FSDataOutputStream) - Method in class org.apache.orc.impl.PhysicalFsWriter.VariantTracker
-
Write the streams in the appropriate area.
- writeStripe(int) - Method in class org.apache.orc.impl.writer.BinaryTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.BooleanTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.ByteTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.DateTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.Decimal64TreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.DecimalTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.DoubleTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.EncryptionTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.FloatTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.IntegerTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.ListTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.MapTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.StringBaseTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.StructTreeWriter
- writeStripe(int) - Method in class org.apache.orc.impl.writer.TimestampTreeWriter
- writeStripe(int) - Method in interface org.apache.orc.impl.writer.TreeWriter
-
Write the stripe out to the file.
- writeStripe(int) - Method in class org.apache.orc.impl.writer.TreeWriterBase
- writeStripe(int) - Method in class org.apache.orc.impl.writer.UnionTreeWriter
- writeTo(OutputStream, int) - Method in interface org.apache.orc.impl.Dictionary
-
Given the position index, write the original string, before being encoded, to the OutputStream.
- writeTo(OutputStream, int) - Method in class org.apache.orc.impl.StringHashTableDictionary
- writeTo(OutputStream, int) - Method in class org.apache.orc.impl.StringRedBlackTree
- writeToTextInternal(OutputStream, int, DynamicIntArray, DynamicByteArray) - Static method in class org.apache.orc.impl.DictionaryUtils
-
Write a UTF8 string from the byteArray, using the offset in index-array, into an OutputStream
- writeVariableLengthBlocks(boolean) - Method in class org.apache.orc.OrcFile.WriterOptions
-
Should the ORC file writer use HDFS variable length blocks, if they are available?
- writeVslong(OutputStream, long) - Method in class org.apache.orc.impl.SerializationUtils
- writeVulong(OutputStream, long) - Method in class org.apache.orc.impl.SerializationUtils
Z
- ZeroPositionProvider() - Constructor for class org.apache.orc.impl.RecordReaderImpl.ZeroPositionProvider
- zigzagDecode(long) - Method in class org.apache.orc.impl.SerializationUtils
-
zigzag decode the given value
- zigzagEncode(long) - Method in class org.apache.orc.impl.SerializationUtils
-
zigzag encode the given value
- ZLIB - Enum constant in enum class org.apache.orc.CompressionKind
- ZlibCodec - Class in org.apache.orc.impl
- ZlibCodec() - Constructor for class org.apache.orc.impl.ZlibCodec
- zonedDateTime(Instant, ZoneId) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a British Cutover zoned date-time in this chronology from an
Instant
. - zonedDateTime(TemporalAccessor) - Method in class org.threeten.extra.chrono.HybridChronology
-
Obtains a British Cutover zoned date-time from another date-time object.
- ZSTD - Enum constant in enum class org.apache.orc.CompressionKind
- ZstdCodec - Class in org.apache.orc.impl
- ZstdCodec() - Constructor for class org.apache.orc.impl.ZstdCodec
- ZstdCodec(int, int) - Constructor for class org.apache.orc.impl.ZstdCodec
- ZstdCompressOptions() - Constructor for class org.apache.orc.OrcFile.ZstdCompressOptions
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
MemoryManager.checkMemory(long, org.apache.orc.MemoryManager.Callback)
instead