Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

A

abort(Executor) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
AbstractArrowFlightJdbcListVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Base Accessor for the Arrow types ListVector, LargeListVector and FixedSizeListVector.
AbstractArrowFlightJdbcListVectorAccessor(IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcListVectorAccessor
 
AbstractArrowFlightJdbcUnionVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Base accessor for UnionVector and DenseUnionVector.
AbstractArrowFlightJdbcUnionVectorAccessor(IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
AbstractCompressionCodec - Class in org.apache.arrow.vector.compression
The base class for concrete compression codecs, providing common logic for all compression codecs.
AbstractCompressionCodec() - Constructor for class org.apache.arrow.vector.compression.AbstractCompressionCodec
 
AbstractContainerVector - Class in org.apache.arrow.vector.complex
Base class for composite vectors.
AbstractContainerVector(String, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.AbstractContainerVector
 
AbstractStructVector - Class in org.apache.arrow.vector.complex
Base class for StructVectors.
AbstractStructVector(String, BufferAllocator, CallBack, AbstractStructVector.ConflictPolicy, boolean) - Constructor for class org.apache.arrow.vector.complex.AbstractStructVector
Base constructor that sets default conflict policy to APPEND.
AbstractStructVector.ConflictPolicy - Enum in org.apache.arrow.vector.complex
Policy to determine how to react when duplicate columns are encountered.
accept(CallHeaders) - Method in class org.apache.arrow.flight.auth2.BasicAuthCredentialWriter
 
accept(CallHeaders) - Method in class org.apache.arrow.flight.auth2.BearerCredentialWriter
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.complex.ListVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.complex.UnionVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
accept(VectorVisitor<OUT, IN>, IN) - Method in class org.apache.arrow.vector.NullVector
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
accept(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
accept(VectorVisitor<OUT, IN>, IN) - Method in interface org.apache.arrow.vector.ValueVector
Accept a generic VectorVisitor and return the result.
acceptPut(FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in interface org.apache.arrow.flight.FlightProducer
Accept uploaded data for a particular stream.
acceptPut(FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.integration.tests.IntegrationProducer
 
acceptPut(FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.NoOpFlightProducer
 
acceptPut(FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Depending on the provided command, method either: 1.
acceptPutPreparedStatementQuery(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
acceptPutPreparedStatementQuery(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Accepts uploaded parameter values for a particular prepared statement query.
acceptPutPreparedStatementQuery(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
acceptPutPreparedStatementUpdate(FlightSql.CommandPreparedStatementUpdate, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
acceptPutPreparedStatementUpdate(FlightSql.CommandPreparedStatementUpdate, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Accepts uploaded data for a particular prepared statement data stream.
acceptPutPreparedStatementUpdate(FlightSql.CommandPreparedStatementUpdate, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
acceptPutStatement(FlightSql.CommandStatementUpdate, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
acceptPutStatement(FlightSql.CommandStatementUpdate, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Accepts uploaded data for a particular SQL query based data stream.
acceptPutStatement(FlightSql.CommandStatementUpdate, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
acceptPutSubstraitPlan(FlightSql.CommandStatementSubstraitPlan, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
acceptPutSubstraitPlan(FlightSql.CommandStatementSubstraitPlan, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Handle a Substrait plan with uploaded data.
accepts(ArrowMessage.ArrowMessageVisitor<T>) - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
accepts(ArrowMessage.ArrowMessageVisitor<T>) - Method in interface org.apache.arrow.vector.ipc.message.ArrowMessage
 
accepts(ArrowMessage.ArrowMessageVisitor<T>) - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
acceptsURL(String) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDriver
 
Action - Class in org.apache.arrow.flight
An opaque action for the service to perform.
Action(String) - Constructor for class org.apache.arrow.flight.Action
 
Action(String, byte[]) - Constructor for class org.apache.arrow.flight.Action
 
ACTION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
ACTION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
ActionType - Class in org.apache.arrow.flight
POJO wrapper around protocol specifics for Flight actions.
ActionType(String, String) - Constructor for class org.apache.arrow.flight.ActionType
Construct a new instance.
actualValueCapacity - Variable in class org.apache.arrow.vector.BaseFixedWidthVector
 
add(ByteBuf, OutputStream, boolean) - Static method in class org.apache.arrow.flight.grpc.AddWritableBuffer
Add the provided ByteBuf to the gRPC BufferChainOutputStream if possible, else copy the buffer to the stream.
add(int) - Method in interface org.apache.arrow.memory.AllocationReservation
Add to the current reservation.
add(T) - Method in class org.apache.arrow.util.AutoCloseables.RollbackCloseable
 
add(String, FieldType) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
addAll(AutoCloseable...) - Method in class org.apache.arrow.util.AutoCloseables.RollbackCloseable
Add all of list to the rollback list.
addAll(Iterable<? extends AutoCloseable>) - Method in class org.apache.arrow.util.AutoCloseables.RollbackCloseable
Add all of list to the rollback list.
addAllEndpoint(Iterable<? extends Flight.FlightEndpoint>) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
addAllInfo(Iterable<? extends Integer>) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
Values are modelled after ODBC's SQLGetInfo() function.
addAllLocation(Iterable<? extends Flight.Location>) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
addAllPath(Iterable<String>) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
addAllTableTypes(Iterable<String>) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
addAxisOrder(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
addBitWidth(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Decimal
 
addBitWidth(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Int
 
addBitWidth(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Time
 
addBodyLength(FlatBufferBuilder, long) - Static method in class org.apache.arrow.flatbuf.Message
 
addBuffers(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
addByteWidth(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
addChildren(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Field
 
addCodec(FlatBufferBuilder, byte) - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
addCompressedAxis(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
addCompression(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
addConnectionEventListener(ConnectionEventListener) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcPooledConnection
 
addCustomMetadata(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Field
 
addCustomMetadata(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
addCustomMetadata(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Message
 
addCustomMetadata(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
addData(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
addData(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
addData(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
addDictionaries(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
addDictionary(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Field
 
addDictionaryKind(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
addEmptyField(String, Types.MinorType) - Method in class org.apache.arrow.driver.jdbc.utils.VectorSchemaRootTransformer.Builder
Adds an empty field to the transformed VectorSchemaRoot schema.
addEmptyField(String, ArrowType) - Method in class org.apache.arrow.driver.jdbc.utils.VectorSchemaRootTransformer.Builder
Adds an empty field to the transformed VectorSchemaRoot schema.
addEndianness(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Schema
 
addEndpoint(Flight.FlightEndpoint) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
addEndpoint(int, Flight.FlightEndpoint) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
addEndpoint(Flight.FlightEndpoint.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
addEndpoint(int, Flight.FlightEndpoint.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
addEndpointBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
addEndpointBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
addFeatures(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
addFields(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
addHeader(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Message
 
addHeaderType(FlatBufferBuilder, byte) - Static method in class org.apache.arrow.flatbuf.Message
 
addId(FlatBufferBuilder, long) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
addId(FlatBufferBuilder, long) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
addIndexType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
addIndicesBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
addIndicesBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
addIndicesBuffers(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
addIndicesStrides(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
addIndicesType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
addIndicesType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
addIndicesType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
addIndptrBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
addIndptrBuffers(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
addIndptrType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
addIndptrType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
addInfo(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
Values are modelled after ODBC's SQLGetInfo() function.
addIsCanonical(FlatBufferBuilder, boolean) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
addIsDelta(FlatBufferBuilder, boolean) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
addIsOrdered(FlatBufferBuilder, boolean) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
addIsSigned(FlatBufferBuilder, boolean) - Static method in class org.apache.arrow.flatbuf.Int
 
addKey(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.KeyValue
 
addKeysSorted(FlatBufferBuilder, boolean) - Static method in class org.apache.arrow.flatbuf.Map
 
addLength(FlatBufferBuilder, long) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
addListSize(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.FixedSizeList
 
addLocation(Flight.Location) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
addLocation(int, Flight.Location) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
addLocation(Flight.Location.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
addLocation(int, Flight.Location.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
addLocationBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
addLocationBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
addMethod(FlatBufferBuilder, byte) - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
addMode(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Union
 
addName(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Field
 
addName(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.TensorDim
 
addNodes(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
addNonZeroLength(FlatBufferBuilder, long) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
addNull() - Method in class org.apache.arrow.consumers.BaseAvroConsumer
 
addNull() - Method in interface org.apache.arrow.consumers.Consumer
Add null value to vector by making writer position + 1.
addNull() - Method in class org.apache.arrow.consumers.SkipConsumer
 
addNullable(FlatBufferBuilder, boolean) - Static method in class org.apache.arrow.flatbuf.Field
 
addOrGet(String, FieldType, Class<T>) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
addOrGet(String, FieldType, Class<T>) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Adds a new field with the given parameters or replaces the existing one and consequently returns the resultant ValueVector.
addOrGet(String, FieldType, Class<T>) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
addOrGet(String, FieldType, Class<T>) - Method in class org.apache.arrow.vector.complex.UnionVector
 
addOrGetFixedSizeList(String, int) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
addOrGetList(String) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
addOrGetMap(String, boolean) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
AddOrGetResult<V extends ValueVector> - Class in org.apache.arrow.vector
Tuple class containing a vector and whether is was created.
AddOrGetResult(V, boolean) - Constructor for class org.apache.arrow.vector.AddOrGetResult
Constructs a new object.
addOrGetStruct(String) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
addOrGetUnion(String) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
addOrGetVector(FieldType) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Initialize the data vector (and execute callback) if it hasn't already been done, returns the data vector.
addOrGetVector(FieldType) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
addOrGetVector(FieldType) - Method in class org.apache.arrow.vector.complex.LargeListVector
Initialize the data vector (and execute callback) if it hasn't already been done, returns the data vector.
addOrGetVector(FieldType) - Method in class org.apache.arrow.vector.complex.ListVector
Initialize the child data vector to field type.
addOrGetVector(FieldType) - Method in interface org.apache.arrow.vector.complex.PromotableVector
 
addPath(String) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
addPathBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
addPrecision(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Decimal
 
addPrecision(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.FloatingPoint
 
addRecordBatches(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
addScale(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Decimal
 
addSchema(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
addShape(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
addShape(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
addSize(FlatBufferBuilder, long) - Static method in class org.apache.arrow.flatbuf.TensorDim
 
addSparseIndex(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
addSparseIndexType(FlatBufferBuilder, byte) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
addStatementEventListener(StatementEventListener) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcPooledConnection
 
addStrides(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
addTableTypes(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
addTableTypesBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
addTimezone(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Timestamp
 
addType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Field
 
addType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
addType(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
addTypeIds(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Union
 
addTypeType(FlatBufferBuilder, byte) - Static method in class org.apache.arrow.flatbuf.Field
 
addTypeType(FlatBufferBuilder, byte) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
addTypeType(FlatBufferBuilder, byte) - Static method in class org.apache.arrow.flatbuf.Tensor
 
addUnit(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Date
 
addUnit(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Duration
 
addUnit(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Interval
 
addUnit(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Time
 
addUnit(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Timestamp
 
addValue(V, int) - Method in interface org.apache.arrow.algorithm.dictionary.DictionaryBuilder
Try to add an element from the target vector to the dictionary.
addValue(V, int) - Method in class org.apache.arrow.algorithm.dictionary.HashTableBasedDictionaryBuilder
Try to add an element from the target vector to the dictionary.
addValue(V, int) - Method in class org.apache.arrow.algorithm.dictionary.SearchTreeBasedDictionaryBuilder
Try to add an element from the target vector to the dictionary.
addValue(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.KeyValue
 
addValues(V) - Method in interface org.apache.arrow.algorithm.dictionary.DictionaryBuilder
Try to add all values from the target vector to the dictionary.
addValues(V) - Method in class org.apache.arrow.algorithm.dictionary.HashTableBasedDictionaryBuilder
Try to add all values from the target vector to the dictionary.
addValues(V) - Method in class org.apache.arrow.algorithm.dictionary.SearchTreeBasedDictionaryBuilder
Try to add all values from the target vector to the dictionary.
addVariadicBufferCounts(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
addVector(byte, FieldVector) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
addVector(FieldVector) - Method in class org.apache.arrow.vector.complex.UnionVector
 
addVector(int, FieldVector) - Method in class org.apache.arrow.vector.table.Table
Returns a new Table created by adding the given vector to the vectors in this Table.
addVector(int, FieldVector) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Add vector to the record batch, producing a new VectorSchemaRoot.
addVersion(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Footer
 
addVersion(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Message
 
AddWritableBuffer - Class in org.apache.arrow.flight.grpc
Allow a user to add a ByteBuf based InputStream directly into GRPC WritableBuffer to avoid an extra copy.
AddWritableBuffer() - Constructor for class org.apache.arrow.flight.grpc.AddWritableBuffer
 
align() - Method in class org.apache.arrow.vector.ipc.WriteChannel
Writes enough bytes to align the channel to an 8-byte boundary.
ALL - Static variable in class org.apache.arrow.flight.Criteria
 
all(Collection<? extends AutoCloseable>) - Static method in class org.apache.arrow.util.AutoCloseables
Returns a new AutoCloseable that calls AutoCloseables.close(Iterable) on autoCloseables when close is called.
alloc() - Method in class io.netty.buffer.NettyArrowBuf
 
allocate(long) - Method in class io.netty.buffer.PooledByteBufAllocatorL
Returns a UnsafeDirectLittleEndian of the given size.
allocate(ValueVector, int, int) - Static method in class org.apache.arrow.vector.AllocationHelper
Allocates the vector.
allocate(ValueVector, int, int, int) - Static method in class org.apache.arrow.vector.AllocationHelper
Allocates memory for a vector assuming given number of values and their width.
allocate() - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
allocate() - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
allocate() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
allocate() - Method in interface org.apache.arrow.vector.complex.writer.FieldWriter
 
allocateBuffer() - Method in interface org.apache.arrow.memory.AllocationReservation
Allocate a buffer whose size is the total of all the add()s made.
allocateNew(ValueVector, int) - Static method in class org.apache.arrow.vector.AllocationHelper
Allocates the exact amount if v is fixed width, otherwise falls back to dynamic allocation.
allocateNew() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
allocateNew(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Allocate memory for the vector to support storing at least the provided number of elements in the vector.
allocateNew() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
allocateNew(long, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Allocate memory for the vector to support storing at least the provided number of elements in the vector.
allocateNew(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
allocateNew() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
allocateNew(long, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Allocate memory for the vector to support storing at least the provided number of elements in the vector.
allocateNew(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
allocateNew() - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
allocateNew() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
allocateNew() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
allocateNew() - Method in class org.apache.arrow.vector.complex.LargeListVector
allocateNew() - Method in class org.apache.arrow.vector.complex.ListVector
allocateNew(int, int) - Method in interface org.apache.arrow.vector.complex.RepeatedFixedWidthVectorLike
Allocate a new memory space for this vector.
allocateNew(int, int, int) - Method in interface org.apache.arrow.vector.complex.RepeatedVariableWidthVectorLike
Allocate a new memory space for this vector.
allocateNew() - Method in class org.apache.arrow.vector.complex.UnionVector
 
allocateNew() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
allocateNew(int) - Method in interface org.apache.arrow.vector.FixedWidthVector
Allocate a new memory space for this vector.
allocateNew() - Method in class org.apache.arrow.vector.NullVector
 
allocateNew() - Method in interface org.apache.arrow.vector.ValueVector
Allocate new buffers.
allocateNew(long, int) - Method in interface org.apache.arrow.vector.VariableWidthVector
Allocate a new memory space for this vector.
allocateNew(int) - Method in interface org.apache.arrow.vector.VariableWidthVector
Allocate a new memory space for this vector.
allocateNew() - Method in class org.apache.arrow.vector.VectorSchemaRoot
Do an adaptive allocation of each vector for memory purposes.
allocateNewSafe() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Allocate memory for the vector.
allocateNewSafe() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Allocate memory for the vector.
allocateNewSafe() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Allocate memory for the vector.
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.LargeListVector
Allocate memory for the vector.
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.ListVector
Allocate memory for the vector.
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.StructVector
 
allocateNewSafe() - Method in class org.apache.arrow.vector.complex.UnionVector
 
allocateNewSafe() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
allocateNewSafe() - Method in class org.apache.arrow.vector.NullVector
 
allocateNewSafe() - Method in interface org.apache.arrow.vector.ValueVector
Allocates new buffers.
allocateOffsetBuffer(long) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
allocateOffsetBuffer(long) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
allocatePrecomputedChildCount(ValueVector, int, int, int) - Static method in class org.apache.arrow.vector.AllocationHelper
Allocates memory for a vector assuming given number of values and their width.
allocateValidityBuffer(long) - Method in class org.apache.arrow.vector.complex.ListVector
 
ALLOCATION_MANAGER_TYPE_ENV_NAME - Static variable in class org.apache.arrow.memory.DefaultAllocationManagerOption
The environmental variable to set the default allocation manager type.
ALLOCATION_MANAGER_TYPE_PROPERTY_NAME - Static variable in class org.apache.arrow.memory.DefaultAllocationManagerOption
The system property to set the default allocation manager type.
AllocationHelper - Class in org.apache.arrow.vector
Helper utility methods for allocating storage for Vectors.
AllocationListener - Interface in org.apache.arrow.memory
An allocation listener being notified for allocation/deallocation
AllocationManager - Class in org.apache.arrow.memory
An AllocationManager is the implementation of a physical memory allocation.
AllocationManager(BufferAllocator) - Constructor for class org.apache.arrow.memory.AllocationManager
 
AllocationManager.Factory - Interface in org.apache.arrow.memory
A factory interface for creating AllocationManager.
AllocationOutcome - Class in org.apache.arrow.memory
Describes the type of outcome that occurred when trying to account for allocation of memory.
AllocationOutcome.Status - Enum in org.apache.arrow.memory
Allocation status code.
AllocationOutcomeDetails - Class in org.apache.arrow.memory
Captures details of allocation for each accountant in the hierarchical chain.
AllocationOutcomeDetails.Entry - Class in org.apache.arrow.memory
Outcome of the allocation request at one accountant in the hierarchy.
AllocationReservation - Interface in org.apache.arrow.memory
Supports cumulative allocation reservation.
allocator(BufferAllocator) - Method in class org.apache.arrow.flight.FlightClient.Builder
 
allocator(BufferAllocator) - Method in class org.apache.arrow.flight.FlightServer.Builder
 
allocator - Variable in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
 
allocator - Variable in class org.apache.arrow.vector.BaseValueVector
 
allocator - Variable in class org.apache.arrow.vector.complex.AbstractContainerVector
 
allocator - Variable in class org.apache.arrow.vector.ipc.ArrowReader
 
allocator - Variable in class org.apache.arrow.vector.ipc.message.MessageChannelReader
 
AllocatorClosedException - Exception in org.apache.arrow.memory
Exception thrown when a closed BufferAllocator is used.
AllocatorClosedException(String) - Constructor for exception org.apache.arrow.memory.AllocatorClosedException
Constructs a new allocator closed exception with a given message.
allowConflictPolicyChanges - Variable in class org.apache.arrow.vector.complex.AbstractStructVector
 
ALREADY_EXISTS - Static variable in class org.apache.arrow.flight.CallStatus
 
ANSI92_ENTRY_SQL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
ANSI92_ENTRY_SQL = 0;
ANSI92_FULL_SQL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
ANSI92_FULL_SQL = 2;
ANSI92_INTERMEDIATE_SQL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
ANSI92_INTERMEDIATE_SQL = 1;
APP_METADATA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightData
 
APP_METADATA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
APP_METADATA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
APP_METADATA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.PutResult
 
append(byte[], int, int) - Method in class org.apache.arrow.vector.util.Text
Append a range of bytes to the end of the given text.
append(boolean, VectorSchemaRoot, VectorSchemaRoot...) - Static method in class org.apache.arrow.vector.util.VectorSchemaRootAppender
Appends a number of VectorSchemaRoots.
append(VectorSchemaRoot, VectorSchemaRoot...) - Static method in class org.apache.arrow.vector.util.VectorSchemaRootAppender
Appends a number of VectorSchemaRoots.
appendToOutgoingHeaders(CallHeaders) - Method in interface org.apache.arrow.flight.auth2.CallHeaderAuthenticator.AuthResult
Appends a header to the outgoing call headers.
apply(ArrowType, int, boolean, FieldVector, JdbcToArrowConfig) - Method in interface org.apache.arrow.adapter.jdbc.JdbcToArrowConfig.JdbcConsumerFactory
 
apply(Decoder) - Method in interface org.apache.arrow.consumers.SkipFunction
 
applyCalendarOffset(long, Calendar) - Static method in class org.apache.arrow.driver.jdbc.utils.DateTimeUtils
Subtracts given Calendar's TimeZone offset from epoch milliseconds.
applyRequestMetadata(CallCredentials.RequestInfo, Executor, CallCredentials.MetadataApplier) - Method in class org.apache.arrow.flight.grpc.CallCredentialAdapter
 
approxEquals(VectorSchemaRoot, VectorValueEqualizer<Float4Vector>, VectorValueEqualizer<Float8Vector>) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Determine if two VectorSchemaRoots are approximately equal using the given functions to calculate difference between float/double values.
approxEquals(VectorSchemaRoot) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Determine if two VectorSchemaRoots are approximately equal using default functions to calculate difference between float/double values.
ApproxEqualsVisitor - Class in org.apache.arrow.vector.compare
Visitor to compare floating point vectors approximately.
ApproxEqualsVisitor(ValueVector, ValueVector) - Constructor for class org.apache.arrow.vector.compare.ApproxEqualsVisitor
Constructs a new instance with default tolerances.
ApproxEqualsVisitor(ValueVector, ValueVector, float, double) - Constructor for class org.apache.arrow.vector.compare.ApproxEqualsVisitor
Constructs a new instance.
ApproxEqualsVisitor(ValueVector, ValueVector, VectorValueEqualizer<Float4Vector>, VectorValueEqualizer<Float8Vector>) - Constructor for class org.apache.arrow.vector.compare.ApproxEqualsVisitor
Constructs a new instance.
ApproxEqualsVisitor(ValueVector, ValueVector, VectorValueEqualizer<Float4Vector>, VectorValueEqualizer<Float8Vector>, BiFunction<ValueVector, ValueVector, Boolean>) - Constructor for class org.apache.arrow.vector.compare.ApproxEqualsVisitor
Constructs a new instance.
array() - Method in class io.netty.buffer.NettyArrowBuf
 
ArrayConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume array type values from ResultSet.
ArrayConsumer(ListVector, JdbcConsumer, int) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
Instantiate a ArrayConsumer.
arrayOffset() - Method in class io.netty.buffer.NettyArrowBuf
 
ArrowBlock - Class in org.apache.arrow.vector.ipc.message
Metadata for an arrow message in a channel.
ArrowBlock(long, int, long) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowBlock
Constructs a new instance.
ArrowBodyCompression - Class in org.apache.arrow.vector.ipc.message
Compression information about data written to a channel.
ArrowBodyCompression(byte, byte) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowBodyCompression
 
arrowBuf() - Method in class io.netty.buffer.NettyArrowBuf
 
ArrowBuf - Class in org.apache.arrow.memory
ArrowBuf serves as a facade over underlying memory by providing several access APIs to read/write data into a chunk of direct memory.
ArrowBuf(ReferenceManager, BufferManager, long, long) - Constructor for class org.apache.arrow.memory.ArrowBuf
Constructs a new ArrowBuf.
ArrowBuffer - Class in org.apache.arrow.vector.ipc.message
Metadata for a buffer written to a channel.
ArrowBuffer(long, long) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowBuffer
Constructs a new instance.
ArrowBufHasher - Interface in org.apache.arrow.memory.util.hash
Utility for calculating the hash code for a consecutive memory region.
ArrowBufPointer - Class in org.apache.arrow.memory.util
Pointer to a memory region within an ArrowBuf.
ArrowBufPointer() - Constructor for class org.apache.arrow.memory.util.ArrowBufPointer
The default constructor.
ArrowBufPointer(ArrowBufHasher) - Constructor for class org.apache.arrow.memory.util.ArrowBufPointer
Constructs an arrow buffer pointer with the specified hasher.
ArrowBufPointer(ArrowBuf, long, long) - Constructor for class org.apache.arrow.memory.util.ArrowBufPointer
Constructs an Arrow buffer pointer.
ArrowBufPointer(ArrowBuf, long, long, ArrowBufHasher) - Constructor for class org.apache.arrow.memory.util.ArrowBufPointer
Constructs an Arrow buffer pointer.
ArrowByteBufAllocator - Class in org.apache.arrow.memory
Deprecated.
This class may be removed in a future release.
ArrowByteBufAllocator(BufferAllocator) - Constructor for class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
ArrowDatabaseMetadata - Class in org.apache.arrow.driver.jdbc
Arrow Flight JDBC's implementation of DatabaseMetaData.
ArrowDictionaryBatch - Class in org.apache.arrow.vector.ipc.message
POJO wrapper around a Dictionary Batch IPC messages (https://arrow.apache.org/docs/format/IPC.html#dictionary-batches)
ArrowDictionaryBatch(long, ArrowRecordBatch) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
Deprecated.
ArrowDictionaryBatch(long, ArrowRecordBatch, boolean) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
Constructs new instance.
ArrowFieldNode - Class in org.apache.arrow.vector.ipc.message
Metadata about Vectors/Arrays that is written to a channel.
ArrowFieldNode(long, long) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowFieldNode
Constructs a new instance.
ArrowFileReader - Class in org.apache.arrow.vector.ipc
An implementation of ArrowReader that reads the standard arrow binary file format.
ArrowFileReader(SeekableReadChannel, BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileReader
 
ArrowFileReader(SeekableByteChannel, BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileReader
 
ArrowFileReader(SeekableReadChannel, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileReader
 
ArrowFileReader(SeekableByteChannel, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileReader
 
ArrowFileWriter - Class in org.apache.arrow.vector.ipc
ArrowWriter that writes out a Arrow files (https://arrow.apache.org/docs/format/IPC.html#file-format).
ArrowFileWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileWriter
 
ArrowFileWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, Map<String, String>) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileWriter
 
ArrowFileWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, IpcOption) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileWriter
 
ArrowFileWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, Map<String, String>, IpcOption) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileWriter
 
ArrowFileWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, Map<String, String>, IpcOption, CompressionCodec.Factory, CompressionUtil.CodecType) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileWriter
 
ArrowFileWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, Map<String, String>, IpcOption, CompressionCodec.Factory, CompressionUtil.CodecType, Optional<Integer>) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileWriter
 
ArrowFlightConnection - Class in org.apache.arrow.driver.jdbc
Connection to the Arrow Flight server.
ArrowFlightConnectionConfigImpl - Class in org.apache.arrow.driver.jdbc.utils
A ConnectionConfig for the ArrowFlightConnection.
ArrowFlightConnectionConfigImpl(Properties) - Constructor for class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
 
ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty - Enum in org.apache.arrow.driver.jdbc.utils
Custom ConnectionProperty for the ArrowFlightConnectionConfigImpl.
ArrowFlightInfoStatement - Interface in org.apache.arrow.driver.jdbc
A Statement that deals with FlightInfo.
ArrowFlightJdbcAccessor - Class in org.apache.arrow.driver.jdbc.accessor
Base Jdbc Accessor.
ArrowFlightJdbcAccessor(IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
ArrowFlightJdbcAccessorFactory - Class in org.apache.arrow.driver.jdbc.accessor
Factory to instantiate the accessors.
ArrowFlightJdbcAccessorFactory() - Constructor for class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessorFactory
 
ArrowFlightJdbcAccessorFactory.WasNullConsumer - Interface in org.apache.arrow.driver.jdbc.accessor
Functional interface used to propagate that the value accessed was null or not.
ArrowFlightJdbcArray - Class in org.apache.arrow.driver.jdbc
Implementation of Array using an underlying FieldVector.
ArrowFlightJdbcArray(FieldVector, long, long) - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
Instantiate an Array backed up by given FieldVector, limited by a start offset and values count.
ArrowFlightJdbcBaseIntVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.numeric
Accessor for the arrow types: TinyIntVector, SmallIntVector, IntVector, BigIntVector, UInt1Vector, UInt2Vector, UInt4Vector and UInt8Vector.
ArrowFlightJdbcBaseIntVectorAccessor(UInt1Vector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBaseIntVectorAccessor(UInt2Vector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBaseIntVectorAccessor(UInt4Vector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBaseIntVectorAccessor(UInt8Vector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBaseIntVectorAccessor(TinyIntVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBaseIntVectorAccessor(SmallIntVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBaseIntVectorAccessor(IntVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBaseIntVectorAccessor(BigIntVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
ArrowFlightJdbcBinaryVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.binary
Accessor for the Arrow types: FixedSizeBinaryVector, VarBinaryVector and LargeVarBinaryVector.
ArrowFlightJdbcBinaryVectorAccessor(FixedSizeBinaryVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
ArrowFlightJdbcBinaryVectorAccessor(VarBinaryVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
ArrowFlightJdbcBinaryVectorAccessor(LargeVarBinaryVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
ArrowFlightJdbcBitVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.numeric
Accessor for the arrow BitVector.
ArrowFlightJdbcBitVectorAccessor(BitVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
Constructor for the BitVectorAccessor.
ArrowFlightJdbcConnectionPoolDataSource - Class in org.apache.arrow.driver.jdbc
ConnectionPoolDataSource implementation for Arrow Flight JDBC Driver.
ArrowFlightJdbcConnectionPoolDataSource(Properties, ArrowFlightConnectionConfigImpl) - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightJdbcConnectionPoolDataSource
Instantiates a new DataSource.
ArrowFlightJdbcCursor - Class in org.apache.arrow.driver.jdbc
Arrow Flight Jdbc's Cursor class.
ArrowFlightJdbcCursor(VectorSchemaRoot) - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightJdbcCursor
 
ArrowFlightJdbcDataSource - Class in org.apache.arrow.driver.jdbc
DataSource implementation for Arrow Flight JDBC Driver.
ArrowFlightJdbcDataSource(Properties, ArrowFlightConnectionConfigImpl) - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
Instantiates a new DataSource.
ArrowFlightJdbcDateVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.calendar
Accessor for the Arrow types: DateDayVector and DateMilliVector.
ArrowFlightJdbcDateVectorAccessor(DateDayVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
Instantiate an accessor for a DateDayVector.
ArrowFlightJdbcDateVectorAccessor(DateMilliVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
Instantiate an accessor for a DateMilliVector.
ArrowFlightJdbcDecimalVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.numeric
ArrowFlightJdbcDecimalVectorAccessor(DecimalVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
ArrowFlightJdbcDecimalVectorAccessor(Decimal256Vector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
ArrowFlightJdbcDenseUnionVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Accessor for the Arrow type DenseUnionVector.
ArrowFlightJdbcDenseUnionVectorAccessor(DenseUnionVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcDenseUnionVectorAccessor
Instantiate an accessor for a DenseUnionVector.
ArrowFlightJdbcDriver - Class in org.apache.arrow.driver.jdbc
JDBC driver for querying data from an Apache Arrow Flight server.
ArrowFlightJdbcDriver() - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDriver
 
ArrowFlightJdbcDurationVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.calendar
Accessor for the Arrow type DurationVector.
ArrowFlightJdbcDurationVectorAccessor(DurationVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDurationVectorAccessor
 
ArrowFlightJdbcFactory - Class in org.apache.arrow.driver.jdbc
Factory for the Arrow Flight JDBC Driver.
ArrowFlightJdbcFactory() - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
ArrowFlightJdbcFixedSizeListVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Accessor for the Arrow type FixedSizeListVector.
ArrowFlightJdbcFixedSizeListVectorAccessor(FixedSizeListVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcFixedSizeListVectorAccessor
 
ArrowFlightJdbcFlightStreamResultSet - Class in org.apache.arrow.driver.jdbc
ResultSet implementation for Arrow Flight used to access the results of multiple FlightStream objects.
ArrowFlightJdbcFloat4VectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.numeric
Accessor for the Float4Vector.
ArrowFlightJdbcFloat4VectorAccessor(Float4Vector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
Instantiate a accessor for the Float4Vector.
ArrowFlightJdbcFloat8VectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.numeric
Accessor for the Float8Vector.
ArrowFlightJdbcFloat8VectorAccessor(Float8Vector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
Instantiate a accessor for the Float8Vector.
ArrowFlightJdbcIntervalVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.calendar
Accessor for the Arrow type IntervalDayVector.
ArrowFlightJdbcIntervalVectorAccessor(IntervalDayVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcIntervalVectorAccessor
Instantiate an accessor for a IntervalDayVector.
ArrowFlightJdbcIntervalVectorAccessor(IntervalYearVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcIntervalVectorAccessor
Instantiate an accessor for a IntervalYearVector.
ArrowFlightJdbcLargeListVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Accessor for the Arrow type LargeListVector.
ArrowFlightJdbcLargeListVectorAccessor(LargeListVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcLargeListVectorAccessor
 
ArrowFlightJdbcListVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Accessor for the Arrow type ListVector.
ArrowFlightJdbcListVectorAccessor(ListVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcListVectorAccessor
 
ArrowFlightJdbcMapVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Accessor for the Arrow type MapVector.
ArrowFlightJdbcMapVectorAccessor(MapVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcMapVectorAccessor
 
ArrowFlightJdbcNullVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl
Accessor for the Arrow type NullVector.
ArrowFlightJdbcNullVectorAccessor(ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.ArrowFlightJdbcNullVectorAccessor
 
ArrowFlightJdbcPooledConnection - Class in org.apache.arrow.driver.jdbc
PooledConnection implementation for Arrow Flight JDBC Driver.
ArrowFlightJdbcStructVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Accessor for the Arrow type StructVector.
ArrowFlightJdbcStructVectorAccessor(StructVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcStructVectorAccessor
 
ArrowFlightJdbcTime - Class in org.apache.arrow.driver.jdbc
Wrapper class for Time objects to include the milliseconds part in ISO 8601 format in this#toString.
ArrowFlightJdbcTime(long) - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightJdbcTime
Constructs this object based on epoch millis.
ArrowFlightJdbcTimeStampVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.calendar
Accessor for the Arrow types extending from TimeStampVector.
ArrowFlightJdbcTimeStampVectorAccessor(TimeStampVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
Instantiate a ArrowFlightJdbcTimeStampVectorAccessor for given vector.
ArrowFlightJdbcTimeVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.calendar
Accessor for the Arrow types: TimeNanoVector, TimeMicroVector, TimeMilliVector and TimeSecVector.
ArrowFlightJdbcTimeVectorAccessor(TimeNanoVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
Instantiate an accessor for a TimeNanoVector.
ArrowFlightJdbcTimeVectorAccessor(TimeMicroVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
Instantiate an accessor for a TimeMicroVector.
ArrowFlightJdbcTimeVectorAccessor(TimeMilliVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
Instantiate an accessor for a TimeMilliVector.
ArrowFlightJdbcTimeVectorAccessor(TimeSecVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
Instantiate an accessor for a TimeSecVector.
ArrowFlightJdbcUnionVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.complex
Accessor for the Arrow type UnionVector.
ArrowFlightJdbcUnionVectorAccessor(UnionVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcUnionVectorAccessor
Instantiate an accessor for a UnionVector.
ArrowFlightJdbcVarCharVectorAccessor - Class in org.apache.arrow.driver.jdbc.accessor.impl.text
Accessor for the Arrow types: VarCharVector and LargeVarCharVector.
ArrowFlightJdbcVarCharVectorAccessor(VarCharVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
ArrowFlightJdbcVarCharVectorAccessor(LargeVarCharVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Constructor for class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
ArrowFlightJdbcVectorSchemaRootResultSet - Class in org.apache.arrow.driver.jdbc
ResultSet implementation used to access a VectorSchemaRoot.
ArrowFlightMetaImpl - Class in org.apache.arrow.driver.jdbc
Metadata handler for Arrow Flight.
ArrowFlightMetaImpl(AvaticaConnection) - Constructor for class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
Constructs a MetaImpl object specific for Arrow Flight.
ArrowFlightPreparedStatement - Class in org.apache.arrow.driver.jdbc
Arrow Flight JBCS's implementation PreparedStatement.
ArrowFlightSqlClientHandler - Class in org.apache.arrow.driver.jdbc.client
A FlightSqlClient handler.
ArrowFlightSqlClientHandler.Builder - Class in org.apache.arrow.driver.jdbc.client
ArrowFlightSqlClientHandler.PreparedStatement - Interface in org.apache.arrow.driver.jdbc.client
A prepared statement handler.
ArrowFlightStatement - Class in org.apache.arrow.driver.jdbc
A SQL statement for querying data from an Arrow Flight server.
ArrowFooter - Class in org.apache.arrow.vector.ipc.message
Footer metadata for the arrow file format.
ArrowFooter(Schema, List<ArrowBlock>, List<ArrowBlock>) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowFooter
 
ArrowFooter(Schema, List<ArrowBlock>, List<ArrowBlock>, Map<String, String>) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowFooter
Constructs a new instance.
ArrowFooter(Schema, List<ArrowBlock>, List<ArrowBlock>, Map<String, String>, MetadataVersion) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowFooter
Constructs a new instance.
ArrowFooter(Footer) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowFooter
Constructs from the corresponding Flatbuffer message.
ArrowMessage - Interface in org.apache.arrow.vector.ipc.message
Interface for Arrow IPC messages (https://arrow.apache.org/docs/format/IPC.html).
ArrowMessage.ArrowMessageVisitor<T> - Interface in org.apache.arrow.vector.ipc.message
Visitor interface for implementations of ArrowMessage.
ArrowReader - Class in org.apache.arrow.vector.ipc
Abstract class to read Schema and ArrowRecordBatches.
ArrowReader(BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowReader
 
ArrowReader(BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowReader
 
ArrowRecordBatch - Class in org.apache.arrow.vector.ipc.message
POJO representation of a RecordBatch IPC message (https://arrow.apache.org/docs/format/Columnar.html#recordbatch-message).
ArrowRecordBatch(int, List<ArrowFieldNode>, List<ArrowBuf>) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
ArrowRecordBatch(int, List<ArrowFieldNode>, List<ArrowBuf>, ArrowBodyCompression) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
ArrowRecordBatch(int, List<ArrowFieldNode>, List<ArrowBuf>, ArrowBodyCompression, boolean) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Construct a record batch from nodes.
ArrowRecordBatch(int, List<ArrowFieldNode>, List<ArrowBuf>, ArrowBodyCompression, boolean, boolean) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Construct a record batch from nodes.
ArrowStreamReader - Class in org.apache.arrow.vector.ipc
This class reads from an input stream and produces ArrowRecordBatches.
ArrowStreamReader(MessageChannelReader, BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
Constructs a streaming reader using a MessageChannelReader.
ArrowStreamReader(MessageChannelReader, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
Constructs a streaming reader using a MessageChannelReader.
ArrowStreamReader(ReadableByteChannel, BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
Constructs a streaming reader from a ReadableByteChannel input.
ArrowStreamReader(ReadableByteChannel, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
Constructs a streaming reader from a ReadableByteChannel input.
ArrowStreamReader(InputStream, BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
Constructs a streaming reader from a ReadableByteChannel input.
ArrowStreamReader(InputStream, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
Constructs a streaming reader from an InputStream.
ArrowStreamWriter - Class in org.apache.arrow.vector.ipc
Writer for the Arrow stream format to send ArrowRecordBatches over a WriteChannel.
ArrowStreamWriter(VectorSchemaRoot, DictionaryProvider, OutputStream) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamWriter
Construct an ArrowStreamWriter with an optional DictionaryProvider for the OutputStream.
ArrowStreamWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamWriter
Construct an ArrowStreamWriter with an optional DictionaryProvider for the WritableByteChannel.
ArrowStreamWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, IpcOption) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamWriter
Construct an ArrowStreamWriter with an optional DictionaryProvider for the WritableByteChannel.
ArrowStreamWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, IpcOption, CompressionCodec.Factory, CompressionUtil.CodecType) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamWriter
Construct an ArrowStreamWriter with compression enabled.
ArrowStreamWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, IpcOption, CompressionCodec.Factory, CompressionUtil.CodecType, Optional<Integer>) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamWriter
Construct an ArrowStreamWriter with compression enabled.
ArrowType - Class in org.apache.arrow.vector.types.pojo
Arrow types Source code generated using FreeMarker template ArrowType.java
ArrowType() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType
 
ArrowType.ArrowTypeID - Enum in org.apache.arrow.vector.types.pojo
 
ArrowType.ArrowTypeVisitor<T> - Interface in org.apache.arrow.vector.types.pojo
to visit the ArrowTypes type.accept(new ArrowTypeVisitor<Type>() { ...
ArrowType.Binary - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Bool - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.ComplexType - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.ComplexTypeVisitor<T> - Class in org.apache.arrow.vector.types.pojo
to visit the Complex ArrowTypes and bundle Primitive ones in one case
ArrowType.Date - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Decimal - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Duration - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.ExtensionType - Class in org.apache.arrow.vector.types.pojo
A user-defined data type that wraps an underlying storage type.
ArrowType.FixedSizeBinary - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.FixedSizeList - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.FloatingPoint - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Int - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Interval - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.LargeBinary - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.LargeList - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.LargeUtf8 - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.List - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Map - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Null - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.PrimitiveType - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.PrimitiveTypeVisitor<T> - Class in org.apache.arrow.vector.types.pojo
to visit the Primitive ArrowTypes and bundle Complex ones under one case
ArrowType.Struct - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Time - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Timestamp - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Union - Class in org.apache.arrow.vector.types.pojo
 
ArrowType.Utf8 - Class in org.apache.arrow.vector.types.pojo
 
ArrowVectorIterator - Class in org.apache.arrow.adapter.jdbc
VectorSchemaRoot iterator for partially converting JDBC data.
ArrowWriter - Class in org.apache.arrow.vector.ipc
Abstract base class for implementing Arrow writers for IPC over a WriteChannel.
ArrowWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel) - Constructor for class org.apache.arrow.vector.ipc.ArrowWriter
 
ArrowWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, IpcOption) - Constructor for class org.apache.arrow.vector.ipc.ArrowWriter
 
ArrowWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, IpcOption, CompressionCodec.Factory, CompressionUtil.CodecType, Optional<Integer>) - Constructor for class org.apache.arrow.vector.ipc.ArrowWriter
Note: fields are not closed when the writer is closed.
asBigInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asBigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asBit(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asBit() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asDateDay(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asDateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asDateMilli(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asDateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asDecimal(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asDecimal(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asDecimal256(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asDecimal256(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asDuration(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asFixedSizeBinary(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asFloat4(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asFloat4() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asFloat8(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asFloat8() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asImmutableList(V...) - Static method in class org.apache.arrow.util.Collections2
Copies the values to a new unmodifiable list.
asInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asIntervalDay(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asIntervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asIntervalMonthDayNano(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asIntervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asIntervalYear(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asIntervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asLargeVarBinary(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asLargeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asLargeVarChar(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asLargeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asList(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asList() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asMap(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asMap(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
ASSERT_ENABLED - Static variable in class org.apache.arrow.memory.util.AssertionUtil
 
AssertionUtil - Class in org.apache.arrow.memory.util
Utility class to that provides AssertionUtil.ASSERT_ENABLED constant to determine if assertions are enabled.
assertOpen() - Method in interface org.apache.arrow.memory.BufferAllocator
Asserts (using java assertions) that the provided allocator is currently open.
asSmallInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asSmallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asStruct(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asStruct() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeMicro(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeMilli(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeNano(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeSec(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampMicro(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampMicroTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampMilli(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampMilliTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampNano(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampNanoTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampSec(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTimeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTimeStampSecTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asTinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asUInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asUInt2(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asUInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asUInt4(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asUInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asUInt8(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asUInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asVarBinary(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
asVarChar(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
asVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
AsyncPutListener - Class in org.apache.arrow.flight
A handler for server-sent application metadata messages during a Flight DoPut operation.
AsyncPutListener() - Constructor for class org.apache.arrow.flight.AsyncPutListener
 
attachVector(V) - Method in class org.apache.arrow.algorithm.sort.StableVectorComparator
 
attachVector(V) - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
Attach both vectors to compare to the same input vector.
attachVectors(FixedSizeListVector, FixedSizeListVector) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeListComparator
 
attachVectors(RepeatedValueVector, RepeatedValueVector) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.RepeatedValueComparator
 
attachVectors(V, V) - Method in class org.apache.arrow.algorithm.sort.StableVectorComparator
 
attachVectors(V, V) - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
Attach vectors to compare.
Auth2Constants - Class in org.apache.arrow.flight.auth2
Constants used in authorization of flight connections.
AuthConstants - Class in org.apache.arrow.flight.auth
Constants used in authorization of flight connections.
authenticate(ClientAuthHandler.ClientAuthSender, Iterator<byte[]>) - Method in class org.apache.arrow.flight.auth.BasicClientAuthHandler
 
authenticate(ServerAuthHandler.ServerAuthSender, Iterator<byte[]>) - Method in class org.apache.arrow.flight.auth.BasicServerAuthHandler
 
authenticate(ClientAuthHandler.ClientAuthSender, Iterator<byte[]>) - Method in interface org.apache.arrow.flight.auth.ClientAuthHandler
Deprecated.
Handle the initial handshake with the server.
authenticate(ServerAuthHandler.ServerAuthSender, Iterator<byte[]>) - Method in interface org.apache.arrow.flight.auth.ServerAuthHandler
Deprecated.
Handle the initial handshake with the client.
authenticate(CallHeaders) - Method in class org.apache.arrow.flight.auth2.BasicCallHeaderAuthenticator
 
authenticate(CallHeaders) - Method in class org.apache.arrow.flight.auth2.BearerTokenAuthenticator
 
authenticate(CallHeaders) - Method in interface org.apache.arrow.flight.auth2.CallHeaderAuthenticator
Validate the auth headers sent by the client.
authenticate(ClientAuthHandler, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Authenticates against the Flight service.
authenticateBasic(String, String) - Method in class org.apache.arrow.flight.FlightClient
Authenticates with a username and password.
authenticateBasicToken(String, String) - Method in class org.apache.arrow.flight.FlightClient
Authenticates with a username and password.
authHandler(ServerAuthHandler) - Method in class org.apache.arrow.flight.FlightServer.Builder
Set the authentication handler.
AUTHORIZATION_HEADER - Static variable in class org.apache.arrow.flight.auth2.Auth2Constants
 
AuthUtilities - Class in org.apache.arrow.flight.auth2
Utility class for completing the auth process.
AutoCloseableLock - Class in org.apache.arrow.memory.util
Simple wrapper class that allows Locks to be released via a try-with-resources block.
AutoCloseableLock(Lock) - Constructor for class org.apache.arrow.memory.util.AutoCloseableLock
 
AutoCloseables - Class in org.apache.arrow.util
Utilities for AutoCloseable classes.
AutoCloseables.RollbackCloseable - Class in org.apache.arrow.util
A closeable wrapper that will close the underlying closeables if a commit does not occur.
AvaticaParameterBinder - Class in org.apache.arrow.driver.jdbc.utils
Convert Avatica PreparedStatement parameters from a list of TypedValue to Arrow and bind them to the VectorSchemaRoot representing the PreparedStatement parameters.
AvaticaParameterBinder(ArrowFlightSqlClientHandler.PreparedStatement, BufferAllocator) - Constructor for class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder
 
AvaticaParameterBinder.BinderVisitor - Class in org.apache.arrow.driver.jdbc.utils
ArrowTypeVisitor that binds Avatica TypedValues to the given FieldVector at the specified index.
AvaticaParameterConverter - Interface in org.apache.arrow.driver.jdbc.converter
Interface for a class in charge of converting between AvaticaParameters and TypedValues and Arrow.
AvroArraysConsumer - Class in org.apache.arrow.consumers
Consumer which consume array type values from avro decoder.
AvroArraysConsumer(ListVector, Consumer) - Constructor for class org.apache.arrow.consumers.AvroArraysConsumer
Instantiate a ArrayConsumer.
AvroBooleanConsumer - Class in org.apache.arrow.consumers
Consumer which consume boolean type values from avro decoder.
AvroBooleanConsumer(BitVector) - Constructor for class org.apache.arrow.consumers.AvroBooleanConsumer
Instantiate a AvroBooleanConsumer.
AvroBytesConsumer - Class in org.apache.arrow.consumers
Consumer which consume bytes type values from avro decoder.
AvroBytesConsumer(VarBinaryVector) - Constructor for class org.apache.arrow.consumers.AvroBytesConsumer
Instantiate a AvroBytesConsumer.
AvroDateConsumer - Class in org.apache.arrow.consumers.logical
Consumer which consume date type values from avro decoder.
AvroDateConsumer(DateDayVector) - Constructor for class org.apache.arrow.consumers.logical.AvroDateConsumer
Instantiate a AvroDateConsumer.
AvroDecimalConsumer - Class in org.apache.arrow.consumers.logical
Consumer which consume decimal type values from avro decoder.
AvroDecimalConsumer(DecimalVector) - Constructor for class org.apache.arrow.consumers.logical.AvroDecimalConsumer
Instantiate a AvroDecimalConsumer.
AvroDecimalConsumer.BytesDecimalConsumer - Class in org.apache.arrow.consumers.logical
Consumer for decimal logical type with original bytes type.
AvroDecimalConsumer.FixedDecimalConsumer - Class in org.apache.arrow.consumers.logical
Consumer for decimal logical type with original fixed type.
AvroDoubleConsumer - Class in org.apache.arrow.consumers
Consumer which consume double type values from avro decoder.
AvroDoubleConsumer(Float8Vector) - Constructor for class org.apache.arrow.consumers.AvroDoubleConsumer
Instantiate a AvroDoubleConsumer.
AvroEnumConsumer - Class in org.apache.arrow.consumers
Consumer which consume enum type values from avro decoder.
AvroEnumConsumer(BaseIntVector) - Constructor for class org.apache.arrow.consumers.AvroEnumConsumer
Instantiate a AvroEnumConsumer.
AvroFixedConsumer - Class in org.apache.arrow.consumers
Consumer which consume fixed type values from avro decoder.
AvroFixedConsumer(FixedSizeBinaryVector, int) - Constructor for class org.apache.arrow.consumers.AvroFixedConsumer
Instantiate a AvroFixedConsumer.
AvroFloatConsumer - Class in org.apache.arrow.consumers
Consumer which consume float type values from avro decoder.
AvroFloatConsumer(Float4Vector) - Constructor for class org.apache.arrow.consumers.AvroFloatConsumer
Instantiate a AvroFloatConsumer.
AvroIntConsumer - Class in org.apache.arrow.consumers
Consumer which consume int type values from avro decoder.
AvroIntConsumer(IntVector) - Constructor for class org.apache.arrow.consumers.AvroIntConsumer
Instantiate a AvroIntConsumer.
AvroLongConsumer - Class in org.apache.arrow.consumers
Consumer which consume long type values from avro decoder.
AvroLongConsumer(BigIntVector) - Constructor for class org.apache.arrow.consumers.AvroLongConsumer
Instantiate a AvroLongConsumer.
AvroMapConsumer - Class in org.apache.arrow.consumers
Consumer which consume map type values from avro decoder.
AvroMapConsumer(MapVector, Consumer) - Constructor for class org.apache.arrow.consumers.AvroMapConsumer
Instantiate a AvroMapConsumer.
AvroNullConsumer - Class in org.apache.arrow.consumers
Consumer which consume null type values from avro decoder.
AvroNullConsumer(NullVector) - Constructor for class org.apache.arrow.consumers.AvroNullConsumer
 
AvroStringConsumer - Class in org.apache.arrow.consumers
Consumer which consume string type values from avro decoder.
AvroStringConsumer(VarCharVector) - Constructor for class org.apache.arrow.consumers.AvroStringConsumer
Instantiate a AvroStringConsumer.
AvroStructConsumer - Class in org.apache.arrow.consumers
Consumer which consume nested record type values from avro decoder.
AvroStructConsumer(StructVector, Consumer[]) - Constructor for class org.apache.arrow.consumers.AvroStructConsumer
Instantiate a AvroStructConsumer.
AvroTimeMicroConsumer - Class in org.apache.arrow.consumers.logical
Consumer which consume date time-micro values from avro decoder.
AvroTimeMicroConsumer(TimeMicroVector) - Constructor for class org.apache.arrow.consumers.logical.AvroTimeMicroConsumer
Instantiate a AvroTimeMicroConsumer.
AvroTimeMillisConsumer - Class in org.apache.arrow.consumers.logical
Consumer which consume date time-millis values from avro decoder.
AvroTimeMillisConsumer(TimeMilliVector) - Constructor for class org.apache.arrow.consumers.logical.AvroTimeMillisConsumer
Instantiate a AvroTimeMilliConsumer.
AvroTimestampMicrosConsumer - Class in org.apache.arrow.consumers.logical
Consumer which consume date timestamp-micro values from avro decoder.
AvroTimestampMicrosConsumer(TimeStampMicroVector) - Constructor for class org.apache.arrow.consumers.logical.AvroTimestampMicrosConsumer
Instantiate a AvroTimestampMicroConsumer.
AvroTimestampMillisConsumer - Class in org.apache.arrow.consumers.logical
Consumer which consume date timestamp-millis values from avro decoder.
AvroTimestampMillisConsumer(TimeStampMilliVector) - Constructor for class org.apache.arrow.consumers.logical.AvroTimestampMillisConsumer
Instantiate a AvroTimestampMillisConsumer.
AvroToArrow - Class in org.apache.arrow
Utility class to convert Avro objects to columnar Arrow format objects.
AvroToArrow() - Constructor for class org.apache.arrow.AvroToArrow
 
AvroToArrowConfig - Class in org.apache.arrow
This class configures the Avro-to-Arrow conversion process.
AvroToArrowConfigBuilder - Class in org.apache.arrow
This class builds AvroToArrowConfigs.
AvroToArrowConfigBuilder(BufferAllocator) - Constructor for class org.apache.arrow.AvroToArrowConfigBuilder
Default constructor for the AvroToArrowConfigBuilder.
avroToArrowIterator(Schema, Decoder, AvroToArrowConfig) - Static method in class org.apache.arrow.AvroToArrow
Fetch the data from Decoder and iteratively convert it to Arrow objects.
AvroToArrowUtils - Class in org.apache.arrow
Class that does most of the work to convert Avro data into Arrow columnar format Vector objects.
AvroToArrowUtils() - Constructor for class org.apache.arrow.AvroToArrowUtils
 
AvroToArrowVectorIterator - Class in org.apache.arrow
VectorSchemaRoot iterator for partially converting avro data.
AvroUnionsConsumer - Class in org.apache.arrow.consumers
Consumer which consume unions type values from avro decoder.
AvroUnionsConsumer(UnionVector, Consumer[], Types.MinorType[]) - Constructor for class org.apache.arrow.consumers.AvroUnionsConsumer
Instantiate an AvroUnionConsumer.
awaitTermination() - Method in class org.apache.arrow.flight.FlightServer
Block until the server shuts down.
awaitTermination(long, TimeUnit) - Method in class org.apache.arrow.flight.FlightServer
Wait for the server to shut down with a timeout.
awaitTermination(long, TimeUnit) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
axisOrder(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
axisOrder stores the sequence in which dimensions were traversed to produce the prefix tree.
axisOrderAsByteBuffer() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
axisOrderInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
axisOrderLength() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
axisOrderVector() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
axisOrderVector(IntVector) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 

B

BackpressureStrategy - Interface in org.apache.arrow.flight
Helper interface to dynamically handle backpressure when implementing FlightProducers.
BackpressureStrategy.CallbackBackpressureStrategy - Class in org.apache.arrow.flight
A back pressure strategy that uses callbacks to notify when the client is ready or cancelled.
BackpressureStrategy.WaitResult - Enum in org.apache.arrow.flight
The state of the client after a call to waitForListener.
BaseAvroConsumer<T extends FieldVector> - Class in org.apache.arrow.consumers
Base class for non-skippable avro consumers.
BaseAvroConsumer(T) - Constructor for class org.apache.arrow.consumers.BaseAvroConsumer
Constructs a base avro consumer.
BaseColumnBinder<V extends FieldVector> - Class in org.apache.arrow.adapter.jdbc.binder
Base class for ColumnBinder implementations.
BaseColumnBinder(V, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.BaseColumnBinder
 
BaseConsumer<V extends ValueVector> - Class in org.apache.arrow.adapter.jdbc.consumer
Base class for all consumers.
BaseConsumer(V, int) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
Constructs a new consumer.
BaseFixedWidthVector - Class in org.apache.arrow.vector
BaseFixedWidthVector provides an abstract interface for implementing vectors of fixed width values.
BaseFixedWidthVector(Field, BufferAllocator, int) - Constructor for class org.apache.arrow.vector.BaseFixedWidthVector
Constructs a new instance.
BaseIntVector - Interface in org.apache.arrow.vector
Interface for all int type vectors.
BaseLargeVariableWidthVector - Class in org.apache.arrow.vector
BaseLargeVariableWidthVector is a base class providing functionality for large strings/large bytes types.
BaseLargeVariableWidthVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.BaseLargeVariableWidthVector
Constructs a new instance.
BaseListVector - Interface in org.apache.arrow.vector.complex
Abstraction for all list type vectors.
BaseModuleInfoCompilerPlugin - Class in org.apache.arrow.maven.plugins
Compiles the first module-info.java file in the project purely syntactically.
BaseModuleInfoCompilerPlugin() - Constructor for class org.apache.arrow.maven.plugins.BaseModuleInfoCompilerPlugin
 
BaseReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template BaseReader.java
BaseReader.ComplexReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseReader.ListReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseReader.MapReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseReader.RepeatedListReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseReader.RepeatedMapReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseReader.RepeatedStructReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseReader.ScalarReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseReader.StructReader - Interface in org.apache.arrow.vector.complex.reader
 
BaseRepeatedValueVector - Class in org.apache.arrow.vector.complex
Base class for Vectors that contain repeated values.
BaseRepeatedValueVector(String, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
BaseRepeatedValueVector(String, BufferAllocator, FieldVector, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
BaseTable - Class in org.apache.arrow.vector.table
Abstract base class for Table.
BaseTable(List<FieldVector>, int, DictionaryProvider) - Constructor for class org.apache.arrow.vector.table.BaseTable
Constructs new instance with the given rowCount, and containing the schema and each of the given vectors.
BaseValueVector - Class in org.apache.arrow.vector
Base class for other Arrow Vector Types.
BaseValueVector(BufferAllocator) - Constructor for class org.apache.arrow.vector.BaseValueVector
 
BaseVariableWidthVector - Class in org.apache.arrow.vector
BaseVariableWidthVector is a base class providing functionality for strings/bytes types.
BaseVariableWidthVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.BaseVariableWidthVector
Constructs a new instance.
BaseWriter - Interface in org.apache.arrow.vector.complex.writer
 
BaseWriter.ComplexWriter - Interface in org.apache.arrow.vector.complex.writer
 
BaseWriter.ListWriter - Interface in org.apache.arrow.vector.complex.writer
 
BaseWriter.MapWriter - Interface in org.apache.arrow.vector.complex.writer
 
BaseWriter.ScalarWriter - Interface in org.apache.arrow.vector.complex.writer
 
BaseWriter.StructOrListWriter - Interface in org.apache.arrow.vector.complex.writer
 
BaseWriter.StructWriter - Interface in org.apache.arrow.vector.complex.writer
 
BASIC_PREFIX - Static variable in class org.apache.arrow.flight.auth2.Auth2Constants
 
BasicAuthCredentialWriter - Class in org.apache.arrow.flight.auth2
Client credentials that use a username and password.
BasicAuthCredentialWriter(String, String) - Constructor for class org.apache.arrow.flight.auth2.BasicAuthCredentialWriter
 
BasicCallHeaderAuthenticator - Class in org.apache.arrow.flight.auth2
A ServerAuthHandler for username/password authentication.
BasicCallHeaderAuthenticator(BasicCallHeaderAuthenticator.CredentialValidator) - Constructor for class org.apache.arrow.flight.auth2.BasicCallHeaderAuthenticator
 
BasicCallHeaderAuthenticator.CredentialValidator - Interface in org.apache.arrow.flight.auth2
Interface that this handler delegates to for validating the incoming headers.
BasicClientAuthHandler - Class in org.apache.arrow.flight.auth
A client auth handler that supports username and password.
BasicClientAuthHandler(String, String) - Constructor for class org.apache.arrow.flight.auth.BasicClientAuthHandler
 
BasicFlightSqlProducer - Class in org.apache.arrow.flight.sql
A FlightSqlProducer that implements getting FlightInfo for each metadata request.
BasicFlightSqlProducer() - Constructor for class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
BasicServerAuthHandler - Class in org.apache.arrow.flight.auth
A ServerAuthHandler for username/password authentication.
BasicServerAuthHandler(BasicServerAuthHandler.BasicAuthValidator) - Constructor for class org.apache.arrow.flight.auth.BasicServerAuthHandler
 
BasicServerAuthHandler.BasicAuthValidator - Interface in org.apache.arrow.flight.auth
Interface that this handler delegates for determining if credentials are valid.
batchAppend(V, V...) - Static method in class org.apache.arrow.vector.util.VectorBatchAppender
Add value vectors in batch.
BEARER_PREFIX - Static variable in class org.apache.arrow.flight.auth2.Auth2Constants
 
BearerCredentialWriter - Class in org.apache.arrow.flight.auth2
Client credentials that use a bearer token.
BearerCredentialWriter(String) - Constructor for class org.apache.arrow.flight.auth2.BearerCredentialWriter
 
BearerTokenAuthenticator - Class in org.apache.arrow.flight.auth2
Partial implementation of CallHeaderAuthenticator for bearer-token based authentication.
BearerTokenAuthenticator(CallHeaderAuthenticator) - Constructor for class org.apache.arrow.flight.auth2.BearerTokenAuthenticator
 
beginSavepoint(FlightSql.ActionBeginSavepointRequest, FlightProducer.CallContext, FlightProducer.StreamListener<FlightSql.ActionBeginSavepointResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
beginSavepoint(FlightSqlClient.Transaction, String, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Create a savepoint within a transaction.
beginSavepoint(FlightSql.ActionBeginSavepointRequest, FlightProducer.CallContext, FlightProducer.StreamListener<FlightSql.ActionBeginSavepointResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Create a savepoint within a transaction.
beginTransaction(FlightSql.ActionBeginTransactionRequest, FlightProducer.CallContext, FlightProducer.StreamListener<FlightSql.ActionBeginTransactionResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
beginTransaction(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Begin a transaction.
beginTransaction(FlightSql.ActionBeginTransactionRequest, FlightProducer.CallContext, FlightProducer.StreamListener<FlightSql.ActionBeginTransactionResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Begin a transaction.
Big - Static variable in class org.apache.arrow.flatbuf.Endianness
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
bigInt() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
bigInt() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
bigInt(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
bigInt(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
BigIntBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for 8-bit integers.
BigIntBinder(BigIntVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.BigIntBinder
 
BigIntBinder(BigIntVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.BigIntBinder
 
BigIntConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume bigint type values from ResultSet.
BigIntConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.BigIntConsumer
 
BigIntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
BigIntHolder() - Constructor for class org.apache.arrow.vector.holders.BigIntHolder
 
BigIntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
BigIntHolderReaderImpl(BigIntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
BigIntReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
BigIntReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
BigIntReaderImpl(BigIntVector) - Constructor for class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
BigIntVector - Class in org.apache.arrow.vector
BigIntVector implements a fixed width vector (8 bytes) of integer values which could be null.
BigIntVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.BigIntVector
Instantiate a BigIntVector.
BigIntVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.BigIntVector
Instantiate a BigIntVector.
BigIntVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.BigIntVector
Instantiate a BigIntVector.
BigIntWriter - Interface in org.apache.arrow.vector.complex.writer
 
BigIntWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
BigIntWriterImpl(BigIntVector) - Constructor for class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
Binary - Class in org.apache.arrow.flatbuf
Opaque binary data
Binary() - Constructor for class org.apache.arrow.flatbuf.Binary
 
Binary - Static variable in class org.apache.arrow.flatbuf.Type
 
binary(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
binary(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
Binary() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
Binary.Vector - Class in org.apache.arrow.flatbuf
 
BinaryAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Binary Arrow types.
BinaryAvaticaParameterConverter(ArrowType.Binary) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.BinaryAvaticaParameterConverter
 
BinaryConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume binary type values from ResultSet.
BinaryConsumer(VarBinaryVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.BinaryConsumer
Instantiate a BinaryConsumer.
binarySearch(V, VectorValueComparator<V>, V, int) - Static method in class org.apache.arrow.algorithm.search.VectorSearcher
Search for a particular element from the key vector in the target vector by binary search.
BinaryView - Class in org.apache.arrow.flatbuf
Logically the same as Binary, but the internal representation uses a view struct that contains the string length and either the string's entire data inline (for small strings) or an inlined prefix, an index of another buffer, and an offset pointing to a slice in that buffer (for non-small strings).
BinaryView() - Constructor for class org.apache.arrow.flatbuf.BinaryView
 
BinaryView - Static variable in class org.apache.arrow.flatbuf.Type
 
BinaryView.Vector - Class in org.apache.arrow.flatbuf
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.BigIntBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.BitBinder
 
bind(PreparedStatement, int, int) - Method in interface org.apache.arrow.adapter.jdbc.binder.ColumnBinder
Bind the given row to the given parameter.
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.DateDayBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.DateMilliBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.Decimal128Binder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.Decimal256Binder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.FixedSizeBinaryBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.Float4Binder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.Float8Binder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.IntBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.ListBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.MapBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.NullableColumnBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.SmallIntBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.Time32Binder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.Time64Binder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.TimeStampBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.TinyIntBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.VarBinaryBinder
 
bind(PreparedStatement, int, int) - Method in class org.apache.arrow.adapter.jdbc.binder.VarCharBinder
 
bind(int, int) - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder.Builder
Bind the given parameter to the given column using the default binder.
bind(int, ColumnBinder) - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder.Builder
Bind the given parameter using the given binder.
bind(List<TypedValue>) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder
Bind the given Avatica values to the prepared statement.
bind(List<TypedValue>, int) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder
Bind the given Avatica values to the prepared statement at the given index.
bindAll() - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder.Builder
Bind each column to the corresponding parameter in order.
BinderVisitor(FieldVector, TypedValue, int) - Constructor for class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
Instantiate a new BinderVisitor.
bindParameter(FieldVector, TypedValue, int) - Method in interface org.apache.arrow.driver.jdbc.converter.AvaticaParameterConverter
Bind a TypedValue to a FieldVector at the given index.
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.BinaryAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.BoolAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.DateAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.DecimalAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.DurationAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.FixedSizeBinaryAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.FixedSizeListAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.FloatingPointAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.IntAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.IntervalAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.LargeBinaryAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.LargeListAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.LargeUtf8AvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.ListAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.MapAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.NullAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.StructAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.TimeAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.TimestampAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.UnionAvaticaParameterConverter
 
bindParameter(FieldVector, TypedValue, int) - Method in class org.apache.arrow.driver.jdbc.converter.impl.Utf8AvaticaParameterConverter
 
bindService(FlightServiceGrpc.AsyncService) - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
bindService() - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceImplBase
 
bindService(TestServiceGrpc.AsyncService) - Static method in class org.apache.arrow.flight.TestServiceGrpc
 
bindService() - Method in class org.apache.arrow.flight.TestServiceGrpc.TestServiceImplBase
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
bit() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
bit() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
bit() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
bit() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
bit() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
bit() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
bit() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
bit(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
bit(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
BitBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for booleans.
BitBinder(BitVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.BitBinder
 
BitBinder(BitVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.BitBinder
 
BitComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.BitComparator
 
BitConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume bit type values from ResultSet.
BitConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.BitConsumer
 
BitHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
BitHolder() - Constructor for class org.apache.arrow.vector.holders.BitHolder
 
BitHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
BitHolderReaderImpl(BitHolder) - Constructor for class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
bitIndex(long) - Static method in class org.apache.arrow.vector.BitVectorHelper
Get the relative index of bit within the byte in validity buffer.
bitIndex(int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Get the relative index of bit within the byte in validity buffer.
BitReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
BitReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
BitReaderImpl(BitVector) - Constructor for class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
BitVector - Class in org.apache.arrow.vector
BitVector implements a fixed width (1 bit) vector of boolean values which could be null.
BitVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.BitVector
Instantiate a BitVector.
BitVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.BitVector
Instantiate a BitVector.
BitVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.BitVector
Instantiate a BitVector.
BitVectorHelper - Class in org.apache.arrow.vector
Helper class for performing generic operations on a bit vector buffer.
bitWidth() - Method in class org.apache.arrow.flatbuf.Decimal
Number of bits per value.
bitWidth() - Method in class org.apache.arrow.flatbuf.Int
 
bitWidth() - Method in class org.apache.arrow.flatbuf.Time
 
BitWriter - Interface in org.apache.arrow.vector.complex.writer
 
BitWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
BitWriterImpl(BitVector) - Constructor for class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
BlobConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume blob type values from ResultSet.
BlobConsumer(BinaryConsumer, int, boolean) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.BlobConsumer
Instantiate a BlobConsumer.
Block - Class in org.apache.arrow.flatbuf
 
Block() - Constructor for class org.apache.arrow.flatbuf.Block
 
Block.Vector - Class in org.apache.arrow.flatbuf
 
BODY_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.Action
 
BODY_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.Result
 
BodyCompression - Class in org.apache.arrow.flatbuf
Optional compression for the memory buffers constituting IPC message bodies.
BodyCompression() - Constructor for class org.apache.arrow.flatbuf.BodyCompression
 
BodyCompression.Vector - Class in org.apache.arrow.flatbuf
 
BodyCompressionMethod - Class in org.apache.arrow.flatbuf
Provided for forward compatibility in case we need to support different strategies for compressing the IPC message body (like whole-body compression rather than buffer-level) in the future
bodyLength() - Method in class org.apache.arrow.flatbuf.Block
Length of the data (this is aligned so there can be a gap between this and the metadata).
bodyLength() - Method in class org.apache.arrow.flatbuf.Message
 
Bool - Class in org.apache.arrow.flatbuf
 
Bool() - Constructor for class org.apache.arrow.flatbuf.Bool
 
Bool - Static variable in class org.apache.arrow.flatbuf.Type
 
Bool() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
Bool.Vector - Class in org.apache.arrow.flatbuf
 
BoolAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Bool Arrow types.
BoolAvaticaParameterConverter(ArrowType.Bool) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.BoolAvaticaParameterConverter
 
booleanVector() - Static method in class org.apache.arrow.vector.BufferLayout
 
BOUNDS_CHECKING_ENABLED - Static variable in class org.apache.arrow.memory.BoundsChecking
 
BoundsChecking - Class in org.apache.arrow.memory
Configuration class to determine if bounds checking should be turned on or off.
BUFFER - Static variable in class org.apache.arrow.flatbuf.BodyCompressionMethod
Each constituent buffer is first compressed with the indicated compressor, and then written with the uncompressed length in the first 8 bytes as a 64-bit little-endian signed integer followed by the compressed buffer bytes (and then padding as required by the protocol).
Buffer - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- A Buffer represents a single contiguous memory segment
Buffer() - Constructor for class org.apache.arrow.flatbuf.Buffer
 
buffer() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
buffer(int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
buffer(int, int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
buffer(long) - Method in interface org.apache.arrow.memory.BufferAllocator
Allocate a new or reused buffer of the provided size.
buffer(long, BufferManager) - Method in interface org.apache.arrow.memory.BufferAllocator
Allocate a new or reused buffer of the provided size.
buffer - Variable in class org.apache.arrow.memory.BufferLedger.TransferResult
 
buffer - Variable in class org.apache.arrow.vector.holders.Decimal256Holder
 
buffer - Variable in class org.apache.arrow.vector.holders.DecimalHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.LargeVarBinaryHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.LargeVarCharHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.NullableDecimal256Holder
 
buffer - Variable in class org.apache.arrow.vector.holders.NullableDecimalHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.NullableVarBinaryHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.NullableVarCharHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.VarBinaryHolder
 
buffer - Variable in class org.apache.arrow.vector.holders.VarCharHolder
 
Buffer.Vector - Class in org.apache.arrow.flatbuf
 
BufferAllocator - Interface in org.apache.arrow.memory
Wrapper class to deal with byte buffer allocation.
BufferBacked - Interface in org.apache.arrow.vector
Content is backed by a buffer and can be loaded/unloaded.
BufferLayout - Class in org.apache.arrow.vector
Metadata class that captures the "type" of an Arrow buffer.
BufferLayout.BufferType - Enum in org.apache.arrow.vector
Enumeration of the different logical types a buffer can have.
BufferLedger - Class in org.apache.arrow.memory
The reference manager that binds an AllocationManager to BufferAllocator and a set of ArrowBuf.
BufferLedger.TransferResult - Class in org.apache.arrow.memory
The outcome of a Transfer.
BufferManager - Interface in org.apache.arrow.memory
Manages a list of ArrowBufs that can be reallocated as needed.
buffers(int) - Method in class org.apache.arrow.flatbuf.RecordBatch
Buffers correspond to the pre-ordered flattened buffer tree The number of buffers appended to this list depends on the schema.
buffers(Buffer, int) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
buffersLength() - Method in class org.apache.arrow.flatbuf.RecordBatch
 
buffersVector() - Method in class org.apache.arrow.flatbuf.RecordBatch
 
buffersVector(Buffer.Vector) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
build() - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder.Builder
Build the binder.
build() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
This builds the JdbcToArrowConfig from the provided BufferAllocator and Calendar.
build() - Method in class org.apache.arrow.AvroToArrowConfigBuilder
This builds the AvroToArrowConfig from the provided params.
build() - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Builds a new ArrowFlightSqlClientHandler from the provided fields.
build() - Method in class org.apache.arrow.driver.jdbc.utils.VectorSchemaRootTransformer.Builder
 
build() - Method in class org.apache.arrow.flight.FlightClient.Builder
Create the client from this builder.
build() - Method in class org.apache.arrow.flight.FlightEndpoint.Builder
Build FlightEndpoint object.
build() - Method in class org.apache.arrow.flight.FlightInfo.Builder
Build FlightInfo object.
build() - Method in class org.apache.arrow.flight.FlightServer.Builder
Create the server for this builder.
build() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
build() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
build(Channel, CallOptions) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
 
build(Channel, CallOptions) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceFutureStub
 
build(Channel, CallOptions) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
 
build() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
build() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
build() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Builds a new instance of FlightSqlColumnMetadata.
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
build(Channel, CallOptions) - Method in class org.apache.arrow.flight.TestServiceGrpc.TestServiceBlockingStub
 
build(Channel, CallOptions) - Method in class org.apache.arrow.flight.TestServiceGrpc.TestServiceFutureStub
 
build(Channel, CallOptions) - Method in class org.apache.arrow.flight.TestServiceGrpc.TestServiceStub
 
build(StructVector) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriterFactory
 
builder(PreparedStatement, VectorSchemaRoot) - Static method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder
Initialize a binder with a builder.
Builder() - Constructor for class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
 
Builder(Schema, BufferAllocator) - Constructor for class org.apache.arrow.driver.jdbc.utils.VectorSchemaRootTransformer.Builder
 
builder() - Static method in class org.apache.arrow.flight.FlightClient
Create a builder for a Flight client.
builder(BufferAllocator, Location) - Static method in class org.apache.arrow.flight.FlightClient
Create a builder for a Flight client.
builder(Ticket, Location...) - Static method in class org.apache.arrow.flight.FlightEndpoint
Create a builder for FlightEndpoint.
builder(Schema, FlightDescriptor, List<FlightEndpoint>) - Static method in class org.apache.arrow.flight.FlightInfo
Create a builder for FlightInfo.
builder() - Static method in class org.apache.arrow.flight.FlightServer
Create a builder for a Flight server.
builder(BufferAllocator, Location, FlightProducer) - Static method in class org.apache.arrow.flight.FlightServer
Create a builder for a Flight server.
Builder() - Constructor for class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Creates a new instance of FlightSqlColumnMetadata.Builder.
buildHistory(StringBuilder, boolean) - Method in class org.apache.arrow.memory.util.HistoricalLog
Write the history of this object to the given StringBuilder.
buildHistory(StringBuilder, int, boolean) - Method in class org.apache.arrow.memory.util.HistoricalLog
Build the history and write it to sb.
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
buildServer(FlightServer.Builder) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
buildServer(FlightServer.Builder) - Method in class org.apache.arrow.flight.integration.tests.OrderedScenario
 
BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.arrow.memory.util.MemoryUtil
The start offset of array data relative to the start address of the array object.
ByteArrayReadableSeekableByteChannel - Class in org.apache.arrow.vector.util
A SeekableByteChannel backed by a byte array.
ByteArrayReadableSeekableByteChannel(byte[]) - Constructor for class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
Construct a new object using the given byteArray as a backing store.
ByteComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.ByteComparator
 
ByteFunctionHelpers - Class in org.apache.arrow.memory.util
Utility methods for memory comparison at a byte level.
byteIndex(long) - Static method in class org.apache.arrow.vector.BitVectorHelper
Get the index of byte corresponding to bit index in validity buffer.
byteIndex(int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Get the index of byte corresponding to bit index in validity buffer.
bytes - Variable in class org.apache.arrow.vector.util.ReusableByteArray
 
bytesAfterMessage() - Method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
Returns the bytes remaining in the buffer after parsing the message from it.
BytesDecimalConsumer(DecimalVector) - Constructor for class org.apache.arrow.consumers.logical.AvroDecimalConsumer.BytesDecimalConsumer
Instantiate a BytesDecimalConsumer.
bytesRead() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
 
bytesRead() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Return the number of bytes read from the ReadChannel.
bytesRead() - Method in class org.apache.arrow.vector.ipc.ArrowStreamReader
Get the number of bytes read from the stream since constructing the reader.
bytesRead() - Method in class org.apache.arrow.vector.ipc.message.MessageChannelReader
Get the number of bytes read from the ReadChannel.
bytesRead() - Method in class org.apache.arrow.vector.ipc.ReadChannel
 
bytesToCodePoint(ByteBuffer) - Static method in class org.apache.arrow.vector.util.Text
Returns the next code point at the current position in the buffer.
bytesToInt(byte[]) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Convert an array of 4 bytes in little-endian to an native-endian i32 value.
bytesWritten() - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
byteVector() - Static method in class org.apache.arrow.vector.BufferLayout
 
byteWidth() - Method in class org.apache.arrow.flatbuf.FixedSizeBinary
Number of bytes per value
byteWidth - Variable in class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
 
byteWidth - Variable in class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
 

C

callBack - Variable in class org.apache.arrow.vector.complex.AbstractContainerVector
 
callBack - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
callBack - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
CallBack - Interface in org.apache.arrow.vector.util
Generic callback interface to be notified of events on value vectors.
CallbackBackpressureStrategy() - Constructor for class org.apache.arrow.flight.BackpressureStrategy.CallbackBackpressureStrategy
 
CallCredentialAdapter - Class in org.apache.arrow.flight.grpc
Adapter class to utilize a CredentialWriter to implement Grpc CallCredentials.
CallCredentialAdapter(Consumer<CallHeaders>) - Constructor for class org.apache.arrow.flight.grpc.CallCredentialAdapter
 
CallHeaderAuthenticator - Interface in org.apache.arrow.flight.auth2
Interface for Server side authentication handlers.
CallHeaderAuthenticator.AuthResult - Interface in org.apache.arrow.flight.auth2
Encapsulates the result of the CallHeaderAuthenticator analysis of headers.
CallHeaders - Interface in org.apache.arrow.flight
A set of metadata key value pairs for a call (request or response).
CallInfo - Class in org.apache.arrow.flight
A description of a Flight call for middleware to inspect.
CallInfo(FlightMethod) - Constructor for class org.apache.arrow.flight.CallInfo
 
CallOption - Interface in org.apache.arrow.flight
Per-call RPC options.
CallOptions - Class in org.apache.arrow.flight
Common call options.
CallOptions() - Constructor for class org.apache.arrow.flight.CallOptions
 
callOptions - Variable in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
 
CallOptions.GrpcCallOption - Interface in org.apache.arrow.flight
CallOptions specific to GRPC stubs.
CallStatus - Class in org.apache.arrow.flight
The result of a Flight RPC, consisting of a status code with an optional description and/or exception that led to the status.
CallStatus(FlightStatusCode, Throwable, String, ErrorFlightMetadata) - Constructor for class org.apache.arrow.flight.CallStatus
Create a new status.
CallStatus(FlightStatusCode) - Constructor for class org.apache.arrow.flight.CallStatus
Create a new status with no cause or description.
camelName() - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
 
cancel() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFlightStreamResultSet
 
cancel() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcVectorSchemaRootResultSet
 
cancel(String, Throwable) - Method in class org.apache.arrow.flight.FlightStream
Cancels sending the stream to a client.
cancel(String, Throwable) - Method in interface org.apache.arrow.flight.FlightStream.Cancellable
 
CANCEL_FLIGHT_INFO - Static variable in interface org.apache.arrow.flight.FlightConstants
 
CANCEL_RESULT_CANCELLED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
The cancellation request is complete.
CANCEL_RESULT_CANCELLING_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
The cancellation request is in progress.
CANCEL_RESULT_NOT_CANCELLABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
The query is not cancellable.
CANCEL_RESULT_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
The cancellation status is unknown.
CANCEL_STATUS_CANCELLED_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CancelStatus
The cancellation request is complete.
CANCEL_STATUS_CANCELLING_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CancelStatus
The cancellation request is in progress.
CANCEL_STATUS_NOT_CANCELLABLE_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CancelStatus
The query is not cancellable.
CANCEL_STATUS_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CancelStatus
The cancellation status is unknown.
cancelCallback() - Method in class org.apache.arrow.flight.BackpressureStrategy.CallbackBackpressureStrategy
Callback to execute when the listener is cancelled.
cancelFlightInfo(CancelFlightInfoRequest, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Cancel execution of a distributed query.
cancelFlightInfo(CancelFlightInfoRequest, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Cancel execution of a distributed query.
cancelFlightInfo(CancelFlightInfoRequest, FlightProducer.CallContext, FlightProducer.StreamListener<CancelStatus>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Explicitly cancel a query.
CancelFlightInfoRequest - Class in org.apache.arrow.flight
A request to cancel a FlightInfo.
CancelFlightInfoRequest(FlightInfo) - Constructor for class org.apache.arrow.flight.CancelFlightInfoRequest
 
CancelFlightInfoResult - Class in org.apache.arrow.flight
The result of cancelling a FlightInfo.
CancelFlightInfoResult(CancelStatus) - Constructor for class org.apache.arrow.flight.CancelFlightInfoResult
 
CANCELLED - Static variable in class org.apache.arrow.flight.CallStatus
 
cancelQuery(FlightInfo, FlightProducer.CallContext, FlightProducer.StreamListener<CancelResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
cancelQuery(FlightInfo, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
cancelQuery(FlightInfo, FlightProducer.CallContext, FlightProducer.StreamListener<CancelResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Deprecated.
Prefer #cancelFlightInfo(FlightInfo, CallContext, StreamListener).
CancelResult - Enum in org.apache.arrow.flight.sql
Deprecated.
Prefer CancelStatus.
CancelStatus - Enum in org.apache.arrow.flight
The result of cancelling a FlightInfo.
capacity(int) - Method in class io.netty.buffer.ExpandableByteBuf
 
capacity(int) - Method in class io.netty.buffer.NettyArrowBuf
 
capacity() - Method in class io.netty.buffer.NettyArrowBuf
 
capacity() - Method in class org.apache.arrow.memory.ArrowBuf
 
capacity(long) - Method in class org.apache.arrow.memory.ArrowBuf
Adjusts the capacity of this buffer.
capAtMaxInt(long) - Static method in class org.apache.arrow.memory.util.LargeMemoryUtil
Returns a min(Integer.MAX_VALUE, length).
CASCADE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
CASCADE = 0;
CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
catalogName(String) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets the catalog name.
cause() - Method in class org.apache.arrow.flight.CallStatus
The exception that led to this result.
CHANGE_ALGORITHM_THRESHOLD - Static variable in class org.apache.arrow.algorithm.sort.FixedWidthInPlaceVectorSorter
If the number of items is smaller than this threshold, we will use another algorithm to sort the data.
CHANGE_ALGORITHM_THRESHOLD - Static variable in class org.apache.arrow.algorithm.sort.IndexSorter
If the number of items is smaller than this threshold, we will use another algorithm to sort the data.
charAt(int) - Method in class org.apache.arrow.vector.util.Text
Returns the Unicode Scalar Value (32-bit integer value) for the character at position.
check(T, T...) - Static method in class org.apache.arrow.vector.complex.StateTool
Verifies currentState is in one of expectedStates, throws an IllegalArgumentException if it isn't.
checkAllBitsEqualTo(ArrowBuf, int, boolean) - Static method in class org.apache.arrow.vector.BitVectorHelper
Tests if all bits in a validity buffer are equal 0 or 1, according to the specified parameter.
checkArgument(boolean) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object...) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, Object, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkBufRefs(ValueVector) - Static method in class org.apache.arrow.vector.BaseValueVector
Checks to ensure that every buffer vv uses has a positive reference count, throws if this precondition isn't met.
checkBytes(long, long) - Method in class org.apache.arrow.memory.ArrowBuf
Allows a function to determine whether not reading a particular string of bytes is valid.
checkedCastToInt(long) - Static method in class org.apache.arrow.memory.util.LargeMemoryUtil
Casts length to an int, but raises an exception the value is outside the range of an int.
checkElementIndex(int, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
checkElementIndex(int, int, String) - Static method in class org.apache.arrow.util.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
checkForUnion(Iterator<Field>, MetadataVersion) - Static method in class org.apache.arrow.vector.validate.MetadataV4UnionChecker
Check the schema, raising an error if an unsupported feature is used (e.g.
checkNotNull(T) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object...) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, Object, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNullsOnCompare() - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
This value is true by default and re-computed when vectors are attached to the comparator.
checkOpen() - Method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Checks if this queue is open.
checkOpen() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Checks whether this client is open.
checkPositionIndex(long, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(long, long, String) - Static method in class org.apache.arrow.util.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndexes(int, int, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkPrecisionAndScale(BigDecimal, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Check that the BigDecimal scale equals the vectorScale and that the BigDecimal precision is less than or equal to the vectorPrecision.
checkPrecisionAndScale(int, int, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Check that the decimal scale equals the vectorScale and that the decimal precision is less than or equal to the vectorPrecision.
checkPrecisionAndScaleNoThrow(BigDecimal, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Check that the BigDecimal scale equals the vectorScale and that the BigDecimal precision is less than or equal to the vectorPrecision.
checkRead(Schema, MetadataVersion) - Static method in class org.apache.arrow.vector.validate.MetadataV4UnionChecker
Check the schema, raising an error if an unsupported feature is used (e.g.
checkState(boolean) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object...) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, char) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, int) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, long) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, Object, Object, Object) - Static method in class org.apache.arrow.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
children(int) - Method in class org.apache.arrow.flatbuf.Field
children apply only to nested data types like Struct, List and Union.
children(Field, int) - Method in class org.apache.arrow.flatbuf.Field
 
childrenLength() - Method in class org.apache.arrow.flatbuf.Field
 
childrenVector() - Method in class org.apache.arrow.flatbuf.Field
 
childrenVector(Field.Vector) - Method in class org.apache.arrow.flatbuf.Field
 
chunkSize - Variable in class org.apache.arrow.memory.rounding.DefaultRoundingPolicy
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
clear() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
clear() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
clear() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
clear() - Method in class org.apache.arrow.memory.ArrowBuf
 
clear() - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Removes all elements from this map, leaving it empty.
clear() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
clear() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
clear() - Method in class org.apache.arrow.vector.BaseValueVector
 
clear() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
clear() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
clear() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
clear() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
clear() - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
clear() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
clear() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
clear() - Method in class org.apache.arrow.vector.complex.ListVector
 
clear() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
clear() - Method in class org.apache.arrow.vector.complex.StructVector
clear() - Method in class org.apache.arrow.vector.complex.UnionVector
 
clear() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
clear() - Method in interface org.apache.arrow.vector.complex.writer.FieldWriter
 
clear() - Method in class org.apache.arrow.vector.dictionary.DictionaryHashTable
Removes all elements from this map, leaving it empty.
clear() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
clear() - Method in class org.apache.arrow.vector.NullVector
 
clear() - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
clear() - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
clear() - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
 
clear() - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
clear() - Method in class org.apache.arrow.vector.util.Text
Clear the string to empty.
clear() - Method in interface org.apache.arrow.vector.ValueVector
Release any owned ArrowBuf and reset the ValueVector to the initial state.
clear() - Method in class org.apache.arrow.vector.VectorSchemaRoot
Release all the memory for each vector held in this root.
clearAction() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Whether to rollback/release the given savepoint.
clearAction() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Whether to commit/rollback the given transaction.
clearAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
Application-defined metadata.
clearAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Application-defined metadata.
clearAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
Application-defined metadata.
clearAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
bytes app_metadata = 1;
clearBody() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
bytes body = 2;
clearBody() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
bytes body = 1;
clearCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies the Catalog to search for the tables.
clearCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the catalog to search for the foreign key table.
clearCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the catalog to search for the primary key table.
clearCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the catalog to search for the table.
clearCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies the Catalog to search for the tables.
clearCmd() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
Opaque value used to express a command.
clearDataBody() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The actual batch of Arrow data.
clearDataHeader() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
Header for message data as described in Message.fbs::Message.
clearDatasetSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
If a result set generating query was provided, dataset_schema contains the schema of the result set.
clearDataType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
Specifies the data type to search for the info.
clearDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the schema to search for the foreign key table.
clearDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the schema to search for the primary key table.
clearDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the schema to search for the table.
clearDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies a filter pattern for schemas to search for.
clearDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for schemas to search for.
clearDefinition() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
clearDescription() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string description = 2;
clearEnd() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
exclusive end
clearEndpoint() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
clearEndpoint() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
clearExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
clearExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
clearExpression() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
bytes expression = 1;
clearFkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the foreign table is.
clearFkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The schema name where the foreign table is.
clearFkTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The foreign table name.
clearFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
clearFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
clearFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
clearIncludeSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies if the Arrow schema should be returned for found tables.
clearInfo() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
clearInfo() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
clearInfo() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
The result of the GetFlightInfo RPC that initiated the query.
clearInfo() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
Values are modelled after ODBC's SQLGetInfo() function.
clearLocation() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
clearName() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
Name for the savepoint.
clearOrdered() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
FlightEndpoints are in the same order as the data.
clearParameters() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Closes the FlightSqlClient.PreparedStatement.parameterBindingRoot, which contains the parameter binding from a FlightSqlClient.PreparedStatement operation, releasing its resources.
clearParameterSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
If the query provided contained parameters, parameter_schema contains the schema of the expected parameters.
clearPassword() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string password = 3;
clearPath() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
clearPayload() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
Arbitrary auth/handshake info.
clearPayload() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
Arbitrary auth/handshake info.
clearPkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the parent table is.
clearPkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The Schema name where the parent table is.
clearPkTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The parent table name.
clearPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
clearPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
clearPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The serialized substrait.Plan to create a prepared statement for.
clearPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
Opaque handle for the prepared statement on the server.
clearPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
Opaque handle for the prepared statement on the server.
clearPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
Opaque handle for the prepared statement on the server.
clearPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
Opaque handle for the prepared statement on the server.
clearProgress() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Query progress.
clearProtocolVersion() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
A defined protocol version
clearProtocolVersion() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
A defined protocol version
clearQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
The valid SQL string to create a prepared statement for.
clearQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
The SQL syntax.
clearQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
The SQL syntax.
clearRecordCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
The number of records updated.
clearRecordsPerBatch() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int32 records_per_batch = 4;
clearRecordsPerStream() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int64 records_per_stream = 3;
clearResult() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
clearSavepointId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
Opaque handle for the savepoint on the server.
clearSavepointId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Opaque handle for the savepoint on the server.
clearSchema() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
clearSchema() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
clearSchema() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
bytes schema = 1;
clearStart() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
inclusive start
clearStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
Unique identifier for the instance of the statement to execute.
clearStatus() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
.arrow.flight.protocol.CancelStatus status = 1;
clearStreamCount() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int32 stream_count = 2;
clearTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the foreign key table to get the foreign keys for.
clearTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the primary key table to get the foreign keys for.
clearTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the table to get the primary keys for.
clearTableNameFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for tables to search for.
clearTableTypes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
clearTicket() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
clearTicket() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
bytes ticket = 1;
clearTotalBytes() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
int64 total_bytes = 5;
clearTotalRecords() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
Set these to -1 if unknown.
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
The transaction to which a savepoint belongs.
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
Opaque handle for the transaction on the server.
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Opaque handle for the transaction on the server.
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
clearTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
clearType() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
string type = 1;
clearType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string type = 1;
clearType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
clearUri() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
string uri = 1;
clearUsername() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string username = 2;
clearVersion() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The Substrait release, e.g.
clearWarnings() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
client(BufferAllocator, Location, FlightClient) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlExtensionScenario
 
client(BufferAllocator, Location, FlightClient) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
client(BufferAllocator, Location, FlightClient) - Method in class org.apache.arrow.flight.integration.tests.OrderedScenario
 
ClientAuthenticationUtils - Class in org.apache.arrow.driver.jdbc.client.utils
Utils for FlightClientHandler authentication.
ClientAuthHandler - Interface in org.apache.arrow.flight.auth
Deprecated.
As of 14.0.0. This implements a stateful "login" flow that does not play well with distributed or stateless systems. It will not be removed, but should not be used. Instead see FlightClient.authenticateBasicToken(String, String).
ClientAuthHandler.ClientAuthSender - Interface in org.apache.arrow.flight.auth
Deprecated.
A communication channel to the server during initial connection.
ClientAuthInterceptor - Class in org.apache.arrow.flight.auth
GRPC client intercepter that handles authentication with the server.
ClientAuthInterceptor() - Constructor for class org.apache.arrow.flight.auth.ClientAuthInterceptor
 
ClientAuthWrapper - Class in org.apache.arrow.flight.auth
Utility class for performing authorization over using a GRPC stub.
ClientAuthWrapper() - Constructor for class org.apache.arrow.flight.auth.ClientAuthWrapper
 
ClientBearerHeaderHandler - Class in org.apache.arrow.flight.auth2
A client header handler that parses the incoming headers for a bearer token.
ClientBearerHeaderHandler() - Constructor for class org.apache.arrow.flight.auth2.ClientBearerHeaderHandler
 
clientCertificate(InputStream, InputStream) - Method in class org.apache.arrow.flight.FlightClient.Builder
Set the trusted TLS certificates.
ClientConnection(Socket) - Constructor for class org.apache.arrow.tools.EchoServer.ClientConnection
 
ClientCookieMiddleware - Class in org.apache.arrow.flight.client
A client middleware for receiving and sending cookie information.
ClientCookieMiddleware.Factory - Class in org.apache.arrow.flight.client
Factory used within FlightClient.
ClientHandshakeWrapper - Class in org.apache.arrow.flight.auth2
Utility class for executing a handshake with a FlightServer.
ClientHandshakeWrapper() - Constructor for class org.apache.arrow.flight.auth2.ClientHandshakeWrapper
 
ClientHeaderHandler - Interface in org.apache.arrow.flight.auth2
Interface for client side header parsing and conversion to CredentialCallOption.
ClientIncomingAuthHeaderMiddleware - Class in org.apache.arrow.flight.auth2
Middleware for capturing bearer tokens sent back from the Flight server.
ClientIncomingAuthHeaderMiddleware.Factory - Class in org.apache.arrow.flight.auth2
Factory used within FlightClient.
ClientInterceptorAdapter - Class in org.apache.arrow.flight.grpc
An adapter between Flight client middleware and gRPC interceptors.
ClientInterceptorAdapter(List<FlightClientMiddleware.Factory>) - Constructor for class org.apache.arrow.flight.grpc.ClientInterceptorAdapter
 
ClobConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume clob type values from ResultSet.
ClobConsumer(VarCharVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.ClobConsumer
Instantiate a ClobConsumer.
clone() - Method in class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.Float4EpsilonEqualizer
 
clone() - Method in class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.Float8EpsilonEqualizer
 
clone() - Method in class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.FloatingPointEpsilonEqualizer
 
clone() - Method in interface org.apache.arrow.vector.compare.VectorValueEqualizer
Creates a equalizer of the same type.
cloneWithTransfer(BufferAllocator) - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Create a new ArrowRecordBatch which has the same information as this batch but whose buffers are owned by that Allocator.
close() - Method in class io.netty.buffer.NettyArrowBuf
 
close() - Method in class org.apache.arrow.adapter.jdbc.ArrowVectorIterator
Clean up resources ONLY WHEN THE VectorSchemaRoot HOLDING EACH BATCH IS REUSED.
close() - Method in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
 
close() - Method in class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
 
close() - Method in class org.apache.arrow.adapter.jdbc.consumer.BlobConsumer
 
close() - Method in class org.apache.arrow.adapter.jdbc.consumer.CompositeJdbcConsumer
 
close() - Method in interface org.apache.arrow.adapter.jdbc.consumer.JdbcConsumer
Close this consumer, do some clean work such as clear reuse ArrowBuf.
close() - Method in class org.apache.arrow.algorithm.deduplicate.VectorRunDeduplicator
 
close() - Method in class org.apache.arrow.AvroToArrowVectorIterator
Clean up resources.
close() - Method in class org.apache.arrow.consumers.AvroArraysConsumer
 
close() - Method in class org.apache.arrow.consumers.AvroMapConsumer
 
close() - Method in class org.apache.arrow.consumers.AvroStructConsumer
 
close() - Method in class org.apache.arrow.consumers.AvroUnionsConsumer
 
close() - Method in class org.apache.arrow.consumers.BaseAvroConsumer
 
close() - Method in class org.apache.arrow.consumers.CompositeAvroConsumer
 
close() - Method in interface org.apache.arrow.consumers.Consumer
Close this consumer when occurs exception to avoid potential leak.
close() - Method in class org.apache.arrow.consumers.SkipConsumer
 
close() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightConnection
 
close() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcConnectionPoolDataSource
 
close() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcCursor
 
close() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFlightStreamResultSet
 
close() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcPooledConnection
 
close() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcVectorSchemaRootResultSet
 
close() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightPreparedStatement
 
close() - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
 
close() - Method in interface org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.PreparedStatement
 
close() - Method in class org.apache.arrow.driver.jdbc.client.CloseableEndpointStreamPair
 
close() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
close() - Method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
 
close() - Method in class org.apache.arrow.flight.FlightClient
Shut down this client.
close() - Method in class org.apache.arrow.flight.FlightClient.ExchangeReaderWriter
Shut down the streams in this call.
close() - Method in class org.apache.arrow.flight.FlightServer
Shutdown the server, waits for up to 6 seconds for successful shutdown before returning.
close() - Method in class org.apache.arrow.flight.FlightStream
Closes the stream (freeing any existing resources).
close() - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
close() - Method in class org.apache.arrow.flight.integration.tests.IntegrationProducer
 
close() - Method in class org.apache.arrow.flight.PutResult
 
close() - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
 
close() - Method in class org.apache.arrow.flight.sql.FlightSqlClient
 
close(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Closes the client.
close() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
 
close() - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
close() - Method in class org.apache.arrow.flight.SyncPutListener
 
close() - Method in interface org.apache.arrow.memory.AllocationReservation
 
close() - Method in class org.apache.arrow.memory.ArrowBuf
 
close() - Method in interface org.apache.arrow.memory.BufferAllocator
Close and release all buffers generated from this buffer pool.
close() - Method in interface org.apache.arrow.memory.BufferManager
 
close() - Method in class org.apache.arrow.memory.util.AutoCloseableLock
 
close() - Method in class org.apache.arrow.tools.EchoServer.ClientConnection
 
close() - Method in class org.apache.arrow.tools.EchoServer
 
close(Throwable, AutoCloseable...) - Static method in class org.apache.arrow.util.AutoCloseables
Closes all autoCloseables if not null and suppresses exceptions by adding them to t.
close(Throwable, Iterable<? extends AutoCloseable>) - Static method in class org.apache.arrow.util.AutoCloseables
Closes all autoCloseables if not null and suppresses exceptions by adding them to t.
close(AutoCloseable...) - Static method in class org.apache.arrow.util.AutoCloseables
Closes all autoCloseables if not null and suppresses subsequent exceptions if more than one.
close(Iterable<? extends AutoCloseable>) - Static method in class org.apache.arrow.util.AutoCloseables
Closes all autoCloseables if not null and suppresses subsequent exceptions if more than one.
close(Iterable<? extends AutoCloseable>...) - Static method in class org.apache.arrow.util.AutoCloseables
Calls AutoCloseables.close(Iterable) on the flattened list of closeables.
close() - Method in class org.apache.arrow.util.AutoCloseables.RollbackCloseable
 
close() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Close the vector and release the associated buffers.
close() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Close the vector and release the associated buffers.
close() - Method in class org.apache.arrow.vector.BaseValueVector
 
close() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Close the vector and release the associated buffers.
close() - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
Clears out all underlying child vectors.
close() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
close() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
close() - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
close() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
close() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
close() - Method in class org.apache.arrow.vector.complex.StructVector
Close the vector and release the associated buffers.
close() - Method in class org.apache.arrow.vector.complex.UnionVector
 
close() - Method in class org.apache.arrow.vector.dictionary.DictionaryProvider.MapDictionaryProvider
 
close() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
close() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Close resources, including vector schema root and dictionary vectors, and the underlying read source.
close(boolean) - Method in class org.apache.arrow.vector.ipc.ArrowReader
Close resources, including vector schema root and dictionary vectors.
close() - Method in class org.apache.arrow.vector.ipc.ArrowStreamWriter
 
close() - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
close() - Method in class org.apache.arrow.vector.ipc.JsonFileReader
 
close() - Method in class org.apache.arrow.vector.ipc.JsonFileWriter
 
close() - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
close() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Releases the buffers.
close() - Method in class org.apache.arrow.vector.ipc.message.MessageChannelReader
Close the ReadChannel.
close() - Method in class org.apache.arrow.vector.ipc.ReadChannel
 
close() - Method in class org.apache.arrow.vector.ipc.WriteChannel
 
close() - Method in class org.apache.arrow.vector.NullVector
 
close() - Method in class org.apache.arrow.vector.table.BaseTable
Closes all the vectors holding data for this table.
close() - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
close() - Method in interface org.apache.arrow.vector.ValueVector
Alternative to clear().
close() - Method in class org.apache.arrow.vector.VectorSchemaRoot
 
CloseableEndpointStreamPair - Class in org.apache.arrow.driver.jdbc.client
Represents a connection to a FlightEndpoint.
CloseableEndpointStreamPair(FlightStream, FlightSqlClient) - Constructor for class org.apache.arrow.driver.jdbc.client.CloseableEndpointStreamPair
 
closeNoChecked(AutoCloseable) - Static method in class org.apache.arrow.util.AutoCloseables
close() an AutoCloseable without throwing a (checked) Exception.
closePreparedStatement(FlightSql.ActionClosePreparedStatementRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
closePreparedStatement(FlightSql.ActionClosePreparedStatementRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Closes a prepared statement on the server.
closePreparedStatement(FlightSql.ActionClosePreparedStatementRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
closeReadSource() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
 
closeReadSource() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Close the underlying read source.
closeReadSource() - Method in class org.apache.arrow.vector.ipc.ArrowStreamReader
Closes the underlying read source.
closeStatement(Meta.StatementHandle) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
CMD_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
CMD_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
An opaque command to generate a dataset.
code() - Method in class org.apache.arrow.flight.CallStatus
The status code describing the result of the RPC.
codec() - Method in class org.apache.arrow.flatbuf.BodyCompression
Compressor library.
Collections2 - Class in org.apache.arrow.util
Utility methods for manipulating Collections and their subclasses/implementations.
Column - Static variable in class org.apache.arrow.flatbuf.SparseMatrixCompressedAxis
 
ColumnBinder - Interface in org.apache.arrow.adapter.jdbc.binder
A helper to bind values from a wrapped Arrow vector to a JDBC PreparedStatement.
ColumnBinderArrowTypeVisitor - Class in org.apache.arrow.adapter.jdbc.binder
Visitor to create the base ColumnBinder for a vector.
ColumnBinderArrowTypeVisitor(FieldVector, Integer) - Constructor for class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
Create a binder using a custom JDBC type code.
columnIndexInResultSet - Variable in class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
 
combineHash(int, int) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
Generate a new hashCode with the given current hashCode and new hashCode.
combineHashCode(int, int) - Static method in class org.apache.arrow.memory.util.hash.MurmurHasher
Combine the current hash code and a new int value to calculate a new hash code.
combineHashCode(int, int) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
 
command(byte[]) - Static method in class org.apache.arrow.flight.FlightDescriptor
 
commit(Meta.ConnectionHandle) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
commit() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
commit(FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Commit a transaction.
commit() - Method in class org.apache.arrow.util.AutoCloseables.RollbackCloseable
 
CommonsCompressionFactory - Class in org.apache.arrow.compression
Default implementation of factory supported LZ4 and ZSTD compression.
CommonsCompressionFactory() - Constructor for class org.apache.arrow.compression.CommonsCompressionFactory
 
CommonUtil - Class in org.apache.arrow.memory.util
Utilities and static methods needed for arrow-memory.
comparator - Variable in class org.apache.arrow.algorithm.dictionary.SearchTreeBasedDictionaryBuilder
The criteria for sorting in the search tree.
compare(int, int) - Method in class org.apache.arrow.algorithm.sort.CompositeVectorComparator
 
compare(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeBinaryComparator
 
compare(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.NullComparator
 
compare(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.VariableWidthComparator
 
compare(int, int) - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
Compare two values, given their indices.
compare(ArrowBuf, long, long, ArrowBuf, long, long) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
Helper function to compare a set of bytes in two ArrowBufs.
compare(ArrowBuf, int, int, byte[], int, int) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
Helper function to compare a set of bytes in ArrowBuf to a ByteArray.
compareBaseFixedWidthVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareBaseLargeVariableWidthVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareBaseVariableWidthVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareDenseUnionVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareDictionaries(List<DictionaryEncoding>, List<DictionaryEncoding>, DictionaryProvider, DictionaryProvider) - Static method in class org.apache.arrow.vector.util.Validator
Validate two Dictionary encodings and dictionaries with id's from the encodings.
compareDictionaryProviders(DictionaryProvider, DictionaryProvider) - Static method in class org.apache.arrow.vector.util.Validator
Validate two dictionary providers are equal in structure and contents.
compareFieldVectors(FieldVector, FieldVector) - Static method in class org.apache.arrow.vector.util.Validator
Validate two arrow FieldVectors are equal.
compareFixedSizeListVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareLargeListVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareListVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.CompositeVectorComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.BitComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.ByteComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DateDayComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DateMilliComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Decimal256Comparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DecimalComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DurationComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeBinaryComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeListComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Float4Comparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Float8Comparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.IntComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.IntervalDayComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.LongComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.NullComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.RepeatedValueComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.ShortComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeMicroComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeMilliComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeNanoComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeSecComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeStampComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt1Comparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt2Comparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt4Comparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt8Comparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.VariableWidthComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.StableVectorComparator
 
compareNotNull(int, int) - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
Compare two values, given their indices.
compareSchemas(Schema, Schema) - Static method in class org.apache.arrow.vector.util.Validator
Validate two arrow schemas are equal.
compareStructVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareTo(ArrowBufPointer) - Method in class org.apache.arrow.memory.util.ArrowBufPointer
Compare two arrow buffer pointers.
compareUnionVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
compareVectorSchemaRoot(VectorSchemaRoot, VectorSchemaRoot) - Static method in class org.apache.arrow.vector.util.Validator
Validate two arrow vectorSchemaRoot are equal.
completed() - Method in interface org.apache.arrow.flight.OutboundStreamListener
Indicate that transmission is finished.
ComplexCopier - Class in org.apache.arrow.vector.complex.impl
 
ComplexCopier() - Constructor for class org.apache.arrow.vector.complex.impl.ComplexCopier
 
ComplexHolder - Class in org.apache.arrow.vector.holders
Represents a single value of a complex type (e.g.
ComplexHolder() - Constructor for class org.apache.arrow.vector.holders.ComplexHolder
 
ComplexTypeVisitor() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
ComplexWriterImpl - Class in org.apache.arrow.vector.complex.impl
Concrete implementation of BaseWriter.ComplexWriter.
ComplexWriterImpl(String, NonNullableStructVector, boolean, boolean) - Constructor for class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
Constructs a new instance.
ComplexWriterImpl(String, NonNullableStructVector, boolean) - Constructor for class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
ComplexWriterImpl(String, NonNullableStructVector) - Constructor for class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
CompositeAvroConsumer - Class in org.apache.arrow.consumers
Composite consumer which hold all consumers.
CompositeAvroConsumer(List<Consumer>) - Constructor for class org.apache.arrow.consumers.CompositeAvroConsumer
 
compositeBuffer() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
compositeBuffer(int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
compositeDirectBuffer() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
compositeDirectBuffer(int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
compositeHeapBuffer() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
compositeHeapBuffer(int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
CompositeJdbcConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Composite consumer which hold all consumers.
CompositeJdbcConsumer(JdbcConsumer[]) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.CompositeJdbcConsumer
Construct an instance.
CompositeVectorComparator - Class in org.apache.arrow.algorithm.sort
A composite vector comparator compares a number of vectors by a number of inner comparators.
CompositeVectorComparator(VectorValueComparator[]) - Constructor for class org.apache.arrow.algorithm.sort.CompositeVectorComparator
 
compress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.vector.compression.AbstractCompressionCodec
 
compress(BufferAllocator, ArrowBuf) - Method in interface org.apache.arrow.vector.compression.CompressionCodec
Compress a buffer.
compress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.vector.compression.NoCompressionCodec
 
COMPRESSED_BODY - Static variable in class org.apache.arrow.flatbuf.Feature
The stream makes use of compressed bodies as described in Message.fbs.
compressedAxis() - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
Which axis, row or column, is compressed
compression() - Method in class org.apache.arrow.flatbuf.RecordBatch
Optional compression of the message body
compression(BodyCompression) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
COMPRESSION_TYPE - Static variable in class org.apache.arrow.vector.compression.NoCompressionCodec
 
CompressionCodec - Interface in org.apache.arrow.vector.compression
The codec for compression/decompression.
CompressionCodec.Factory - Interface in org.apache.arrow.vector.compression
Factory to create compression codec.
CompressionType - Class in org.apache.arrow.flatbuf
 
CompressionUtil - Class in org.apache.arrow.vector.compression
Utilities for data compression/decompression.
CompressionUtil.CodecType - Enum in org.apache.arrow.vector.compression
Compression codec types corresponding to flat buffer implementation in CompressionType.
computeBodyLength() - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
computeBodyLength() - Method in interface org.apache.arrow.vector.ipc.message.ArrowMessage
 
computeBodyLength() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Computes the size of the serialized body for this recordBatch.
concatBits(ArrowBuf, int, ArrowBuf, int, ArrowBuf) - Static method in class org.apache.arrow.vector.BitVectorHelper
Concat two validity buffers.
config() - Static method in class org.apache.arrow.vector.ipc.JsonFileWriter
 
connect(String, Properties) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDriver
 
connectionClosed(ConnectionEvent) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcConnectionPoolDataSource
 
connectionErrorOccurred(ConnectionEvent) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcConnectionPoolDataSource
 
ConnectionWrapper - Class in org.apache.arrow.driver.jdbc.utils
Auxiliary wrapper class for Connection, used on ArrowFlightJdbcPooledConnection.
ConnectionWrapper(Connection) - Constructor for class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
Constants - Class in org.apache.arrow.adapter.jdbc
String constants used for metadata returned on Vectors.
consume(InputStream) - Method in class org.apache.arrow.adapter.jdbc.consumer.BinaryConsumer
consume a InputStream.
consume(ResultSet) - Method in class org.apache.arrow.adapter.jdbc.consumer.BlobConsumer
 
consume(ResultSet) - Method in class org.apache.arrow.adapter.jdbc.consumer.CompositeJdbcConsumer
 
consume(ResultSet) - Method in interface org.apache.arrow.adapter.jdbc.consumer.JdbcConsumer
Consume a specific type value from ResultSet and write it to vector.
consume(ResultSet) - Method in class org.apache.arrow.adapter.jdbc.consumer.MapConsumer
 
consume(ResultSet) - Method in class org.apache.arrow.adapter.jdbc.consumer.NullConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroArraysConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroBooleanConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroBytesConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroDoubleConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroEnumConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroFixedConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroFloatConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroIntConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroLongConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroMapConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroNullConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroStringConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroStructConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.AvroUnionsConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.CompositeAvroConsumer
Consume decoder data.
consume(Decoder) - Method in interface org.apache.arrow.consumers.Consumer
Consume a specific type value from avro decoder and write it to vector.
consume(Decoder) - Method in class org.apache.arrow.consumers.logical.AvroDateConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.logical.AvroDecimalConsumer.BytesDecimalConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.logical.AvroDecimalConsumer.FixedDecimalConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.logical.AvroTimeMicroConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.logical.AvroTimeMillisConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.logical.AvroTimestampMicrosConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.logical.AvroTimestampMillisConsumer
 
consume(Decoder) - Method in class org.apache.arrow.consumers.SkipConsumer
 
Consumer<T extends FieldVector> - Interface in org.apache.arrow.consumers
Interface that is used to consume values from avro decoder.
container - Variable in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
container - Variable in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
containsKey(String) - Method in interface org.apache.arrow.flight.CallHeaders
Check whether the given metadata key is present.
containsKey(String) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
containsKey(String) - Method in class org.apache.arrow.flight.FlightCallHeaders
 
containsKey(String) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
containsKey(K) - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Returns whether this map contains the specified key.
containsKey(K) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
containsKey(Object) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
containsKey(K) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
 
containsKey(K) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
containsValue(V) - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Returns whether this map contains the specified value.
contentToTSVString() - Method in class org.apache.arrow.vector.table.BaseTable
Returns a tab separated value of vectors (based on their java object representation).
contentToTSVString() - Method in class org.apache.arrow.vector.VectorSchemaRoot
Returns a tab separated value of vectors (based on their java object representation).
ContextPropagatingExecutorService - Class in org.apache.arrow.flight.grpc
An ExecutorService that propagates the Context.
ContextPropagatingExecutorService(ExecutorService) - Constructor for class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
convert(FileInputStream, OutputStream) - Static method in class org.apache.arrow.tools.FileToStream
Reads an Arrow file from in and writes it back to out.
convert(InputStream, OutputStream) - Static method in class org.apache.arrow.tools.StreamToFile
Reads an Arrow stream from in and writes it to out.
convertArrowFieldsToAvaticaParameters(List<Field>) - Static method in class org.apache.arrow.driver.jdbc.utils.ConvertUtils
Convert Fields To Avatica Parameters.
convertArrowFieldsToColumnMetaDataList(List<Field>) - Static method in class org.apache.arrow.driver.jdbc.utils.ConvertUtils
Convert Fields To Column MetaData List functions.
convertField(Field) - Static method in class org.apache.arrow.vector.types.pojo.Field
Constructs a new instance from a flatbuffer representation of the field.
convertSchema(Schema) - Static method in class org.apache.arrow.vector.types.pojo.Schema
Converts a flatbuffer schema to its POJO representation.
ConvertUtils - Class in org.apache.arrow.driver.jdbc.utils
Convert objects between Arrow and Avatica.
copy(int, int) - Method in class io.netty.buffer.ExpandableByteBuf
 
copy(int, int) - Method in class io.netty.buffer.LargeBuffer
 
copy() - Method in class io.netty.buffer.NettyArrowBuf
 
copy(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
copy(FieldReader, FieldWriter) - Static method in class org.apache.arrow.vector.complex.impl.ComplexCopier
Do a deep copy of the value in input into output
copy() - Method in class org.apache.arrow.vector.table.Table
Returns a deep copy of this table.
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
 
copyAsField(String, TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, IntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, BitWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
copyAsField(String, BigIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
 
copyAsField(String, BitWriter) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
 
copyAsField(String, DateDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
 
copyAsField(String, DateMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
 
copyAsField(String, Decimal256Writer) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
 
copyAsField(String, DecimalWriter) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
 
copyAsField(String, DurationWriter) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
 
copyAsField(String, FixedSizeBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
 
copyAsField(String, Float4Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
 
copyAsField(String, Float8Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
 
copyAsField(String, IntervalDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
 
copyAsField(String, IntervalMonthDayNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
 
copyAsField(String, IntervalYearWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
 
copyAsField(String, IntWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
 
copyAsField(String, LargeVarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
 
copyAsField(String, LargeVarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
 
copyAsField(String, SmallIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
 
copyAsField(String, TimeMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
 
copyAsField(String, TimeMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
 
copyAsField(String, TimeNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
 
copyAsField(String, TimeSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
 
copyAsField(String, TimeStampMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
 
copyAsField(String, TimeStampMicroTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
 
copyAsField(String, TimeStampMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
 
copyAsField(String, TimeStampMilliTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
 
copyAsField(String, TimeStampNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
 
copyAsField(String, TimeStampNanoTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
 
copyAsField(String, TimeStampSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
 
copyAsField(String, TimeStampSecTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
 
copyAsField(String, TinyIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
 
copyAsField(String, UInt1Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
 
copyAsField(String, UInt2Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
 
copyAsField(String, UInt4Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
 
copyAsField(String, UInt8Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
 
copyAsField(String, VarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
 
copyAsField(String, VarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
 
copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
copyAsValue(UnionWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
copyAsValue(DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
copyAsValue(DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
copyAsValue(FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
copyAsValue(FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
copyAsValue(BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
 
copyAsValue(BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(UnionWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
 
copyAsValue(BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
copyAsValue(TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
copyAsValue(TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
copyAsValue(TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
copyAsValue(TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
copyAsValue(TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
copyAsValue(TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
copyAsValue(TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
copyAsValue(TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
copyAsValue(UnionLargeListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
copyAsValue(UnionWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
copyAsValue(UnionWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
copyAsValue(DenseUnionWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
copyAsValue(BaseWriter.ListWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedListReader
 
copyAsValue(BaseWriter.MapWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedMapReader
 
copyAsValue(BaseWriter.StructWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedStructReader
 
copyAsValue(BigIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
 
copyAsValue(BitWriter) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
 
copyAsValue(DateDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
 
copyAsValue(DateMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
 
copyAsValue(Decimal256Writer) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
 
copyAsValue(DecimalWriter) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
 
copyAsValue(DurationWriter) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
 
copyAsValue(FixedSizeBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
 
copyAsValue(Float4Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
 
copyAsValue(Float8Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
 
copyAsValue(IntervalDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
 
copyAsValue(IntervalMonthDayNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
 
copyAsValue(IntervalYearWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
 
copyAsValue(IntWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
 
copyAsValue(LargeVarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
 
copyAsValue(LargeVarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
 
copyAsValue(SmallIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
 
copyAsValue(TimeMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
 
copyAsValue(TimeMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
 
copyAsValue(TimeNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
 
copyAsValue(TimeSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
 
copyAsValue(TimeStampMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
 
copyAsValue(TimeStampMicroTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
 
copyAsValue(TimeStampMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
 
copyAsValue(TimeStampMilliTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
 
copyAsValue(TimeStampNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
 
copyAsValue(TimeStampNanoTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
 
copyAsValue(TimeStampSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
 
copyAsValue(TimeStampSecTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
 
copyAsValue(TinyIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
 
copyAsValue(UInt1Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
 
copyAsValue(UInt2Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
 
copyAsValue(UInt4Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
 
copyAsValue(UInt8Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
 
copyAsValue(VarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
 
copyAsValue(VarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
 
copyBytes() - Method in class org.apache.arrow.vector.util.Text
Get a copy of the bytes that is exactly the length of the data.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Copy a cell value from a particular index in source vector to a particular position in this vector.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Copy a cell value from a particular index in source vector to a particular position in this vector.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseValueVector
 
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Copy a cell value from a particular index in source vector to a particular position in this vector.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.BitVector
Copy a cell value from a particular index in source vector to a particular position in this vector.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.LargeListVector
Copy a cell value from a particular index in source vector to a particular position in this vector.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.ListVector
Copy a cell value from a particular index in source vector to a particular position in this vector.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
Copies the element at fromIndex in the provided vector to thisIndex.
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.UnionVector
 
copyFrom(int, int, ValueVector) - Method in class org.apache.arrow.vector.NullVector
 
copyFrom(int, int, ValueVector) - Method in interface org.apache.arrow.vector.ValueVector
Copy a cell value from a particular index in source vector to a particular position in this vector.
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Same as BaseFixedWidthVector.copyFrom(int, int, ValueVector) except that it handles the case when the capacity of the vector needs to be expanded before copy.
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Same as BaseLargeVariableWidthVector.copyFrom(int, int, ValueVector) except that it handles the case when the capacity of the vector needs to be expanded before copy.
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseValueVector
 
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Same as BaseVariableWidthVector.copyFrom(int, int, ValueVector) except that it handles the case when the capacity of the vector needs to be expanded before copy.
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.LargeListVector
Same as LargeListVector.copyFrom(int, int, ValueVector) except that it handles the case when the capacity of the vector needs to be expanded before copy.
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.ListVector
Same as ListVector.copyFrom(int, int, ValueVector) except that it handles the case when the capacity of the vector needs to be expanded before copy.
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.complex.UnionVector
 
copyFromSafe(int, int, ValueVector) - Method in class org.apache.arrow.vector.NullVector
 
copyFromSafe(int, int, ValueVector) - Method in interface org.apache.arrow.vector.ValueVector
Same as ValueVector.copyFrom(int, int, ValueVector) except that it handles the case when the capacity of the vector needs to be expanded before copy.
copyReader(FieldReader) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
copyReader(FieldReader) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
copyReaderToField(String, FieldReader) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
copyStructureFrom(DictionaryProvider, BufferAllocator) - Method in class org.apache.arrow.vector.dictionary.DictionaryProvider.MapDictionaryProvider
Initialize the map structure from another provider, but with empty vectors.
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
copyValueSafe(int, int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector.StructTransferPair
 
copyValueSafe(int, int) - Method in class org.apache.arrow.vector.complex.StructVector.NullableStructTransferPair
 
copyValueSafe(int, int) - Method in class org.apache.arrow.vector.TimeStampVector.TransferImpl
 
copyValueSafe(int, int) - Method in interface org.apache.arrow.vector.util.TransferPair
 
create(ResultSet, JdbcToArrowConfig) - Static method in class org.apache.arrow.adapter.jdbc.ArrowVectorIterator
Create a ArrowVectorIterator to partially convert data.
create(Decoder, Schema, AvroToArrowConfig) - Static method in class org.apache.arrow.AvroToArrowVectorIterator
Create a ArrowVectorIterator to partially convert data.
create(BufferAllocator, long) - Method in interface org.apache.arrow.memory.AllocationManager.Factory
create(BufferAllocator, long) - Method in class org.apache.arrow.memory.DefaultAllocationManagerFactory
 
create(ByteBuffer, int) - Static method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
Creates a new MessageMetadataResult by parsing it from the beginning of the buffer.
create(Schema, BufferAllocator) - Static method in class org.apache.arrow.vector.VectorSchemaRoot
Creates a new set of empty vectors corresponding to the given schema.
createAccessor(ValueVector, IntSupplier, ArrowFlightJdbcAccessorFactory.WasNullConsumer) - Static method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessorFactory
Create an accessor according to its type.
createAccessorForVector(ValueVector) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
createAccessorForVector(ValueVector) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcDenseUnionVectorAccessor
 
createAccessorForVector(ValueVector) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcUnionVectorAccessor
 
createAccessors(List<ColumnMetaData>, Calendar, ArrayImpl.Factory) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcCursor
 
createArrayOf(String, Object...) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createAxisOrderVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
createBitmaskFromEnums(ProtocolMessageEnum...) - Static method in class org.apache.arrow.flight.sql.util.SqlInfoOptionsUtils
Creates a bitmask that translates to the specified enums.
createBitmaskFromEnums(Collection<ProtocolMessageEnum>) - Static method in class org.apache.arrow.flight.sql.util.SqlInfoOptionsUtils
Creates a bitmask that translates to the specified enums.
createBlob() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createBlock(FlatBufferBuilder, long, int, long) - Static method in class org.apache.arrow.flatbuf.Block
 
createBodyCompression(FlatBufferBuilder, byte, byte) - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
createBodyCompression(CompressionCodec) - Static method in class org.apache.arrow.vector.compression.CompressionUtil
Creates the ArrowBodyCompression object, given the CompressionCodec.
createBuffer(FlatBufferBuilder, long, long) - Static method in class org.apache.arrow.flatbuf.Buffer
 
createChildrenVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Field
 
createClob() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createCodec(CompressionUtil.CodecType) - Method in class org.apache.arrow.compression.CommonsCompressionFactory
 
createCodec(CompressionUtil.CodecType, int) - Method in class org.apache.arrow.compression.CommonsCompressionFactory
 
createCodec(CompressionUtil.CodecType) - Method in interface org.apache.arrow.vector.compression.CompressionCodec.Factory
Creates the codec based on the codec type.
createCodec(CompressionUtil.CodecType, int) - Method in interface org.apache.arrow.vector.compression.CompressionCodec.Factory
Creates the codec based on the codec type and compression level.
createCodec(CompressionUtil.CodecType) - Method in class org.apache.arrow.vector.compression.NoCompressionCodec.Factory
 
createCodec(CompressionUtil.CodecType, int) - Method in class org.apache.arrow.vector.compression.NoCompressionCodec.Factory
 
createConsumer(ListVector, JdbcConsumer, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
Creates a consumer for ListVector.
createConsumer(BigIntVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BigIntConsumer
Creates a consumer for BigIntVector.
createConsumer(VarBinaryVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BinaryConsumer
Creates a consumer for VarBinaryVector.
createConsumer(BitVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BitConsumer
Creates a consumer for BitVector.
createConsumer(BinaryConsumer, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BlobConsumer
Creates a consumer for VarBinaryVector.
createConsumer(VarCharVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.ClobConsumer
Creates a consumer for VarCharVector.
createConsumer(DateDayVector, int, boolean, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.consumer.DateConsumer
Creates a consumer for DateMilliVector.
createConsumer(Decimal256Vector, int, boolean, RoundingMode) - Static method in class org.apache.arrow.adapter.jdbc.consumer.Decimal256Consumer
Creates a consumer for Decimal256Vector.
createConsumer(DecimalVector, int, boolean, RoundingMode) - Static method in class org.apache.arrow.adapter.jdbc.consumer.DecimalConsumer
Creates a consumer for DecimalVector.
createConsumer(Float8Vector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.DoubleConsumer
Creates a consumer for Float8Vector.
createConsumer(Float4Vector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.FloatConsumer
Creates a consumer for Float4Vector.
createConsumer(IntVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.IntConsumer
Creates a consumer for IntVector.
createConsumer(MapVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.MapConsumer
Creates a consumer for MapVector.
createConsumer(SmallIntVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.SmallIntConsumer
Creates a consumer for SmallIntVector.
createConsumer(TimeMilliVector, int, boolean, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.consumer.TimeConsumer
Creates a consumer for TimeMilliVector.
createConsumer(TimeStampMilliVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.TimestampConsumer
Creates a consumer for TimeStampMilliVector.
createConsumer(TimeStampMilliTZVector, int, boolean, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.consumer.TimestampTZConsumer
Creates a consumer for TimeStampMilliTZVector.
createConsumer(TinyIntVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.TinyIntConsumer
Creates a consumer for TinyIntVector.
createConsumer(VarCharVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.VarCharConsumer
Creates a consumer for VarCharVector.
createCustomMetadataVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Field
 
createCustomMetadataVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Footer
 
createCustomMetadataVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Message
 
createCustomMetadataVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Schema
 
createDate(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Date
 
createDecimal(FlatBufferBuilder, int, int, int) - Static method in class org.apache.arrow.flatbuf.Decimal
 
createDecimal(int, int, Integer) - Static method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
createDefaultComparator(T) - Static method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators
Create the default comparator for the vector.
createDictionaryBatch(FlatBufferBuilder, long, int, boolean) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
createDictionaryEncoding(FlatBufferBuilder, long, int, boolean, short) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
createDriverVersion() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDriver
 
createDuration(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Duration
 
createFeaturesVector(FlatBufferBuilder, long[]) - Static method in class org.apache.arrow.flatbuf.Schema
 
createField(FlatBufferBuilder, int, boolean, byte, int, int, int, int) - Static method in class org.apache.arrow.flatbuf.Field
 
createFieldNode(FlatBufferBuilder, long, long) - Static method in class org.apache.arrow.flatbuf.FieldNode
 
createFieldsVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Schema
 
createFixedSizeBinary(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
createFixedSizeList(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.FixedSizeList
 
createFlightClient(BufferAllocator, ManagedChannel) - Static method in class org.apache.arrow.flight.FlightGrpcUtils
Creates a Flight client.
createFlightClientWithSharedChannel(BufferAllocator, ManagedChannel) - Static method in class org.apache.arrow.flight.FlightGrpcUtils
Creates a Flight client.
createFlightService(BufferAllocator, FlightProducer, ServerAuthHandler, ExecutorService) - Static method in class org.apache.arrow.flight.FlightGrpcUtils
Creates a Flight service.
createFlightSqlClient(String, int) - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
Creates a FlightSqlClient to be used with the example methods.
createFloatingPoint(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.FloatingPoint
 
createFooter(FlatBufferBuilder, short, int, int, int, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
createGetter(int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcCursor
ArrowFlightJdbcAccessors do not use AbstractCursor.Getter, as it would box primitive types and cause performance issues.
createIndicesStridesVector(FlatBufferBuilder, long[]) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
createInnerVisitor(ValueVector, ValueVector, BiFunction<ValueVector, ValueVector, Boolean>) - Method in class org.apache.arrow.vector.compare.ApproxEqualsVisitor
 
createInnerVisitor(ValueVector, ValueVector, BiFunction<ValueVector, ValueVector, Boolean>) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
createInt(FlatBufferBuilder, int, boolean) - Static method in class org.apache.arrow.flatbuf.Int
 
createInterval(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Interval
 
createKeyValue(FlatBufferBuilder, int, int) - Static method in class org.apache.arrow.flatbuf.KeyValue
 
createMap(FlatBufferBuilder, boolean) - Static method in class org.apache.arrow.flatbuf.Map
 
createMessage(FlatBufferBuilder, short, byte, int, long, int) - Static method in class org.apache.arrow.flatbuf.Message
 
createMeta(AvaticaConnection) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDriver
 
createNClob() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createNew() - Method in class org.apache.arrow.algorithm.sort.CompositeVectorComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.BitComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.ByteComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DateDayComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DateMilliComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Decimal256Comparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DecimalComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DurationComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeBinaryComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeListComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Float4Comparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Float8Comparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.IntComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.IntervalDayComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.LongComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.NullComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.RepeatedValueComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.ShortComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeMicroComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeMilliComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeNanoComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeSecComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeStampComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt1Comparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt2Comparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt4Comparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt8Comparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.DefaultVectorComparators.VariableWidthComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.StableVectorComparator
 
createNew() - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
Creates a comparator of the same type.
createNewDataSource(Properties) - Static method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcConnectionPoolDataSource
createNewDataSource(Properties) - Static method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
createNewHandler(FlightClient, ArrowFlightSqlClientHandler.Builder, Collection<CallOption>) - Static method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Creates a new ArrowFlightSqlClientHandler from the provided client and options.
createNewQueue(ExecutorService) - Static method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Creates a new FlightEndpointDataQueue from the provided ExecutorService.
createNewSingleVector(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
createNewSingleVector(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
createParameter(Field) - Method in interface org.apache.arrow.driver.jdbc.converter.AvaticaParameterConverter
Create an AvaticaParameter from the given Field.
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.BinaryAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.BoolAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.DateAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.DecimalAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.DurationAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.FixedSizeBinaryAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.FixedSizeListAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.FloatingPointAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.IntAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.IntervalAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.LargeBinaryAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.LargeListAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.LargeUtf8AvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.ListAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.MapAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.NullAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.StructAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.TimeAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.TimestampAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.UnionAvaticaParameterConverter
 
createParameter(Field) - Method in class org.apache.arrow.driver.jdbc.converter.impl.Utf8AvaticaParameterConverter
 
createPreparedStatement(FlightSql.ActionCreatePreparedStatementRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
createPreparedStatement(FlightSql.ActionCreatePreparedStatementRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Creates a prepared statement on the server and returns a handle and metadata for in a FlightSql.ActionCreatePreparedStatementResult object in a Result object.
createPreparedStatement(FlightSql.ActionCreatePreparedStatementRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
createPreparedSubstraitPlan(FlightSql.ActionCreatePreparedSubstraitPlanRequest, FlightProducer.CallContext, FlightProducer.StreamListener<FlightSql.ActionCreatePreparedStatementResult>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
createPreparedSubstraitPlan(FlightSql.ActionCreatePreparedSubstraitPlanRequest, FlightProducer.CallContext, FlightProducer.StreamListener<FlightSql.ActionCreatePreparedStatementResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Pre-compile a Substrait plan.
createRecordBatch(FlatBufferBuilder, long, int, int, int, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
createSchema(FlatBufferBuilder, short, int, int, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
createShapeVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
createShapeVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Tensor
 
createSparseTensorIndexCSF(FlatBufferBuilder, int, int, int, int, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
createSQLXML() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createStatement() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createStatement(int, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createStatement(int, int, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createStridesVector(FlatBufferBuilder, long[]) - Static method in class org.apache.arrow.flatbuf.Tensor
 
createStruct(String, Object...) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
createTensorDim(FlatBufferBuilder, long, int) - Static method in class org.apache.arrow.flatbuf.TensorDim
 
createTime(FlatBufferBuilder, short, int) - Static method in class org.apache.arrow.flatbuf.Time
 
createTimestamp(FlatBufferBuilder, short, int) - Static method in class org.apache.arrow.flatbuf.Timestamp
 
createTypeIdsVector(FlatBufferBuilder, int[]) - Static method in class org.apache.arrow.flatbuf.Union
 
createUnion(FlatBufferBuilder, short, int) - Static method in class org.apache.arrow.flatbuf.Union
 
createVariadicBufferCountsVector(FlatBufferBuilder, long[]) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
createVector(BufferAllocator) - Method in class org.apache.arrow.vector.types.pojo.Field
Construct a new vector of this type using the given allocator.
CredentialCallOption - Class in org.apache.arrow.flight.grpc
Method option for supplying credentials to method calls.
CredentialCallOption(Consumer<CallHeaders>) - Constructor for class org.apache.arrow.flight.grpc.CredentialCallOption
 
Criteria - Class in org.apache.arrow.flight
An opaque object that can be used to filter a list of streams available from a server.
Criteria(byte[]) - Constructor for class org.apache.arrow.flight.Criteria
 
currentIndex - Variable in class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
 
currentIndex - Variable in class org.apache.arrow.consumers.BaseAvroConsumer
 
customMetadata(int) - Method in class org.apache.arrow.flatbuf.Field
User-defined metadata
customMetadata(KeyValue, int) - Method in class org.apache.arrow.flatbuf.Field
 
customMetadata(int) - Method in class org.apache.arrow.flatbuf.Footer
User-defined metadata
customMetadata(KeyValue, int) - Method in class org.apache.arrow.flatbuf.Footer
 
customMetadata(int) - Method in class org.apache.arrow.flatbuf.Message
 
customMetadata(KeyValue, int) - Method in class org.apache.arrow.flatbuf.Message
 
customMetadata(int) - Method in class org.apache.arrow.flatbuf.Schema
 
customMetadata(KeyValue, int) - Method in class org.apache.arrow.flatbuf.Schema
 
customMetadataLength() - Method in class org.apache.arrow.flatbuf.Field
 
customMetadataLength() - Method in class org.apache.arrow.flatbuf.Footer
 
customMetadataLength() - Method in class org.apache.arrow.flatbuf.Message
 
customMetadataLength() - Method in class org.apache.arrow.flatbuf.Schema
 
customMetadataVector() - Method in class org.apache.arrow.flatbuf.Field
 
customMetadataVector(KeyValue.Vector) - Method in class org.apache.arrow.flatbuf.Field
 
customMetadataVector() - Method in class org.apache.arrow.flatbuf.Footer
 
customMetadataVector(KeyValue.Vector) - Method in class org.apache.arrow.flatbuf.Footer
 
customMetadataVector() - Method in class org.apache.arrow.flatbuf.Message
 
customMetadataVector(KeyValue.Vector) - Method in class org.apache.arrow.flatbuf.Message
 
customMetadataVector() - Method in class org.apache.arrow.flatbuf.Schema
 
customMetadataVector(KeyValue.Vector) - Method in class org.apache.arrow.flatbuf.Schema
 

D

data() - Method in class org.apache.arrow.flatbuf.DictionaryBatch
 
data(RecordBatch) - Method in class org.apache.arrow.flatbuf.DictionaryBatch
 
data() - Method in class org.apache.arrow.flatbuf.SparseTensor
The location and size of the tensor's data
data(Buffer) - Method in class org.apache.arrow.flatbuf.SparseTensor
 
data() - Method in class org.apache.arrow.flatbuf.Tensor
The location and size of the tensor's data
data(Buffer) - Method in class org.apache.arrow.flatbuf.Tensor
 
data - Variable in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
data - Variable in class org.apache.arrow.vector.complex.impl.UnionReader
 
DATA_BODY_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightData
 
DATA_HEADER_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightData
 
DATA_TYPE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
DATA_VECTOR_NAME - Static variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
DATA_VECTOR_NAME - Static variable in class org.apache.arrow.vector.complex.LargeListVector
 
DATA_VECTOR_NAME - Static variable in class org.apache.arrow.vector.complex.MapVector
 
dataBuffer(int) - Static method in class org.apache.arrow.vector.BufferLayout
Returns a databuffer for the given bitwidth.
dataDefinitionCausesTransactionCommit() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
dataDefinitionIgnoredInTransactions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
DATASET_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
DataSizeRoundingUtil - Class in org.apache.arrow.vector.util
Utilities for rounding data size.
Date - Class in org.apache.arrow.flatbuf
Date is either a 32-bit or 64-bit signed integer type representing an elapsed time since UNIX epoch (1970-01-01), stored in either of two units: * Milliseconds (64 bits) indicating UNIX time elapsed since the epoch (no leap seconds), where the values are evenly divisible by 86400000 * Days (32 bits) since the UNIX epoch
Date() - Constructor for class org.apache.arrow.flatbuf.Date
 
Date - Static variable in class org.apache.arrow.flatbuf.Type
 
Date(DateUnit) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
Date.Vector - Class in org.apache.arrow.flatbuf
 
DateAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Date Arrow types.
DateAvaticaParameterConverter(ArrowType.Date) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.DateAvaticaParameterConverter
 
DateConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume date type values from ResultSet.
DateConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.DateConsumer
 
dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
dateDay() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
dateDay() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
dateDay(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
DateDayBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for 32-bit dates.
DateDayBinder(DateDayVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.DateDayBinder
 
DateDayBinder(DateDayVector, Calendar) - Constructor for class org.apache.arrow.adapter.jdbc.binder.DateDayBinder
 
DateDayBinder(DateDayVector, Calendar, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.DateDayBinder
 
DateDayComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DateDayComparator
 
DateDayHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
DateDayHolder() - Constructor for class org.apache.arrow.vector.holders.DateDayHolder
 
DateDayHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
DateDayHolderReaderImpl(DateDayHolder) - Constructor for class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
DateDayReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
DateDayReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
DateDayReaderImpl(DateDayVector) - Constructor for class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
DateDayVector - Class in org.apache.arrow.vector
DateDayVector implements a fixed width (4 bytes) vector of date values which could be null.
DateDayVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.DateDayVector
Instantiate a DateDayVector.
DateDayVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.DateDayVector
Instantiate a DateDayVector.
DateDayVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.DateDayVector
Instantiate a DateDayVector.
DateDayWriter - Interface in org.apache.arrow.vector.complex.writer
 
DateDayWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
DateDayWriterImpl(DateDayVector) - Constructor for class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
dateMilli() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
dateMilli() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
dateMilli(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
DateMilliBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for 64-bit dates.
DateMilliBinder(DateMilliVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.DateMilliBinder
 
DateMilliBinder(DateMilliVector, Calendar) - Constructor for class org.apache.arrow.adapter.jdbc.binder.DateMilliBinder
 
DateMilliBinder(DateMilliVector, Calendar, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.DateMilliBinder
 
DateMilliComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DateMilliComparator
 
DateMilliHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
DateMilliHolder() - Constructor for class org.apache.arrow.vector.holders.DateMilliHolder
 
DateMilliHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
DateMilliHolderReaderImpl(DateMilliHolder) - Constructor for class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
DateMilliReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
DateMilliReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
DateMilliReaderImpl(DateMilliVector) - Constructor for class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
DateMilliVector - Class in org.apache.arrow.vector
DateMilliVector implements a fixed width vector (8 bytes) of date values which could be null.
DateMilliVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.DateMilliVector
Instantiate a DateMilliVector.
DateMilliVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.DateMilliVector
Instantiate a DateMilliVector.
DateMilliVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.DateMilliVector
Instantiate a DateMilliVector.
DateMilliWriter - Interface in org.apache.arrow.vector.complex.writer
 
DateMilliWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
DateMilliWriterImpl(DateMilliVector) - Constructor for class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
dateTimeTZFormat - Static variable in class org.apache.arrow.vector.util.DateUtility
 
DateTimeUtils - Class in org.apache.arrow.driver.jdbc.utils
Datetime utility functions.
DateUnit - Class in org.apache.arrow.flatbuf
 
DateUnit - Enum in org.apache.arrow.vector.types
Resolutions that dates can be stored at.
DateUtility - Class in org.apache.arrow.vector.util
Utility class for Date, DateTime, TimeStamp, Interval data types.
DAY - Static variable in class org.apache.arrow.flatbuf.DateUnit
 
DAY_TIME - Static variable in class org.apache.arrow.flatbuf.IntervalUnit
 
days - Variable in class org.apache.arrow.vector.holders.IntervalDayHolder
 
days - Variable in class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
 
days - Variable in class org.apache.arrow.vector.holders.NullableIntervalDayHolder
 
days - Variable in class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
 
daysToStandardMillis - Static variable in class org.apache.arrow.vector.util.DateUtility
 
DB_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
DB_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
DB_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
DB_SCHEMA_FILTER_PATTERN_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
DB_SCHEMA_FILTER_PATTERN_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
Decimal - Class in org.apache.arrow.flatbuf
Exact decimal value represented as an integer value in two's complement.
Decimal() - Constructor for class org.apache.arrow.flatbuf.Decimal
 
Decimal - Static variable in class org.apache.arrow.flatbuf.Type
 
decimal(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
decimal() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
decimal(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
decimal(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
decimal() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
decimal(String, int, int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
decimal(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Decimal(int, int) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
Deprecated.
This API will be removed in a future release.
Decimal(int, int, int) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
Decimal.Vector - Class in org.apache.arrow.flatbuf
 
Decimal128Binder - Class in org.apache.arrow.adapter.jdbc.binder
A binder for 128-bit decimals.
Decimal128Binder(DecimalVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Decimal128Binder
 
Decimal128Binder(DecimalVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Decimal128Binder
 
decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
decimal256() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
decimal256() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
decimal256(String, int, int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
decimal256(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Decimal256Binder - Class in org.apache.arrow.adapter.jdbc.binder
A binder for 256-bit decimals.
Decimal256Binder(Decimal256Vector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Decimal256Binder
 
Decimal256Binder(Decimal256Vector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Decimal256Binder
 
Decimal256Comparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Decimal256Comparator
 
Decimal256Consumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume decimal type values from ResultSet.
Decimal256Consumer(Decimal256Vector, int) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.Decimal256Consumer
Constructs a new consumer.
Decimal256Consumer(Decimal256Vector, int, RoundingMode) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.Decimal256Consumer
Constructs a new consumer, with optional coercibility.
Decimal256Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
Decimal256Holder() - Constructor for class org.apache.arrow.vector.holders.Decimal256Holder
 
Decimal256HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
Decimal256HolderReaderImpl(Decimal256Holder) - Constructor for class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
Decimal256Reader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
Decimal256ReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
Decimal256ReaderImpl(Decimal256Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
Decimal256Vector - Class in org.apache.arrow.vector
Decimal256Vector implements a fixed width vector (32 bytes) of decimal values which could be null.
Decimal256Vector(String, BufferAllocator, int, int) - Constructor for class org.apache.arrow.vector.Decimal256Vector
Instantiate a Decimal256Vector.
Decimal256Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.Decimal256Vector
Instantiate a Decimal256Vector.
Decimal256Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.Decimal256Vector
Instantiate a Decimal256Vector.
Decimal256Writer - Interface in org.apache.arrow.vector.complex.writer
 
Decimal256WriterImpl - Class in org.apache.arrow.vector.complex.impl
 
Decimal256WriterImpl(Decimal256Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
DecimalAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Decimal Arrow types.
DecimalAvaticaParameterConverter(ArrowType.Decimal) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.DecimalAvaticaParameterConverter
 
DecimalComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DecimalComparator
 
DecimalConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume decimal type values from ResultSet.
DecimalConsumer(DecimalVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.DecimalConsumer
Constructs a new consumer.
DecimalConsumer(DecimalVector, int, RoundingMode) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.DecimalConsumer
Constructs a new consumer, with optional coercibility.
DecimalHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
DecimalHolder() - Constructor for class org.apache.arrow.vector.holders.DecimalHolder
 
DecimalHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
DecimalHolderReaderImpl(DecimalHolder) - Constructor for class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
DecimalReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
DecimalReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
DecimalReaderImpl(DecimalVector) - Constructor for class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
DecimalUtility - Class in org.apache.arrow.vector.util
Utility methods for configurable precision Decimal values (e.g.
DecimalVector - Class in org.apache.arrow.vector
DecimalVector implements a fixed width vector (16 bytes) of decimal values which could be null.
DecimalVector(String, BufferAllocator, int, int) - Constructor for class org.apache.arrow.vector.DecimalVector
Instantiate a DecimalVector.
DecimalVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.DecimalVector
Instantiate a DecimalVector.
DecimalVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.DecimalVector
Instantiate a DecimalVector.
DecimalWriter - Interface in org.apache.arrow.vector.complex.writer
 
DecimalWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
DecimalWriterImpl(DecimalVector) - Constructor for class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
decode(ValueVector, Dictionary) - Static method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
Decodes a dictionary encoded array using the provided dictionary.
decode(ValueVector, Dictionary, BufferAllocator) - Static method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
Decodes a dictionary encoded array using the provided dictionary.
decode(ValueVector) - Method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
Decodes a vector with the dictionary in this encoder.
decode(StructVector) - Method in class org.apache.arrow.vector.dictionary.StructSubfieldEncoder
Decodes a dictionary subfields encoded vector using the provided dictionary.
decode(StructVector, DictionaryProvider.MapDictionaryProvider, BufferAllocator) - Static method in class org.apache.arrow.vector.dictionary.StructSubfieldEncoder
Decodes a dictionary subfields encoded vector using the provided dictionary.
decode(String, long) - Method in class org.apache.arrow.vector.table.BaseTable
Returns a ValueVector containing the decoded version of the vector with the given name.
decode(byte[]) - Static method in class org.apache.arrow.vector.util.Text
Converts the provided byte array to a String using the UTF-8 encoding.
decode(byte[], int, int) - Static method in class org.apache.arrow.vector.util.Text
 
decode(byte[], int, int, boolean) - Static method in class org.apache.arrow.vector.util.Text
Converts the provided byte array to a String using the UTF-8 encoding.
decodeListSubField(BaseListVector) - Method in class org.apache.arrow.vector.dictionary.ListSubfieldEncoder
Decodes a dictionary subfields encoded vector using the provided dictionary.
decodeListSubField(BaseListVector, Dictionary, BufferAllocator) - Static method in class org.apache.arrow.vector.dictionary.ListSubfieldEncoder
Decodes a dictionary subfields encoded vector using the provided dictionary.
decompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.vector.compression.AbstractCompressionCodec
 
decompress(BufferAllocator, ArrowBuf) - Method in interface org.apache.arrow.vector.compression.CompressionCodec
Decompress a buffer.
decompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.vector.compression.NoCompressionCodec
 
decrementAllocationMonitor() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
DEFAULT - Static variable in class org.apache.arrow.vector.ipc.message.IpcOption
 
DEFAULT - Static variable in enum org.apache.arrow.vector.types.MetadataVersion
 
DEFAULT_ALLOCATION_CUTOFF_VALUE - Static variable in class org.apache.arrow.memory.NettyAllocationManager
The default cut-off value for switching allocation strategies.
DEFAULT_BATCH_SIZE - Static variable in class org.apache.arrow.AvroToArrowVectorIterator
 
DEFAULT_BODY_COMPRESSION - Static variable in class org.apache.arrow.vector.compression.NoCompressionCodec
 
DEFAULT_DATA_VECTOR - Static variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
DEFAULT_DATA_VECTOR - Static variable in class org.apache.arrow.vector.complex.LargeListVector
 
DEFAULT_DOUBLE_EPSILON - Static variable in class org.apache.arrow.vector.compare.ApproxEqualsVisitor
 
DEFAULT_FLOAT_EPSILON - Static variable in class org.apache.arrow.vector.compare.ApproxEqualsVisitor
Default epsilons for diff functions.
DEFAULT_MAX_LEN - Static variable in class org.apache.arrow.vector.util.Text
 
DEFAULT_REPEAT_PER_RECORD - Static variable in interface org.apache.arrow.vector.complex.RepeatedValueVector
 
DEFAULT_ROUNDING_POLICY - Static variable in class org.apache.arrow.memory.rounding.DefaultRoundingPolicy
The singleton instance.
DEFAULT_TARGET_BATCH_SIZE - Static variable in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
 
DEFAULT_TYPE_COMPARATOR - Static variable in class org.apache.arrow.vector.compare.RangeEqualsVisitor
Default type comparator.
DefaultAllocationManagerFactory - Class in org.apache.arrow.memory
The default Allocation Manager Factory for a module.
DefaultAllocationManagerFactory() - Constructor for class org.apache.arrow.memory.DefaultAllocationManagerFactory
 
DefaultAllocationManagerOption - Class in org.apache.arrow.memory
A class for choosing the default allocation manager.
DefaultAllocationManagerOption() - Constructor for class org.apache.arrow.memory.DefaultAllocationManagerOption
 
DefaultAllocationManagerOption.AllocationManagerType - Enum in org.apache.arrow.memory
The allocation manager type.
defaultDataVectorName - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
defaultDataVectorName - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
DefaultRoundingPolicy - Class in org.apache.arrow.memory.rounding
The default rounding policy.
defaultValue() - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
 
DefaultVectorComparators - Class in org.apache.arrow.algorithm.sort
Default comparator implementations for different types of vectors.
DefaultVectorComparators.BitComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for bit type.
DefaultVectorComparators.ByteComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for bytes.
DefaultVectorComparators.DateDayComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for DateDay type.
DefaultVectorComparators.DateMilliComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for DateMilli type.
DefaultVectorComparators.Decimal256Comparator - Class in org.apache.arrow.algorithm.sort
Default comparator for Decimal256 type.
DefaultVectorComparators.DecimalComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for Decimal type.
DefaultVectorComparators.DurationComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for Duration type.
DefaultVectorComparators.FixedSizeBinaryComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for FixedSizeBinaryVector.
DefaultVectorComparators.FixedSizeListComparator<T extends ValueVector> - Class in org.apache.arrow.algorithm.sort
Default comparator for RepeatedValueVector.
DefaultVectorComparators.Float4Comparator - Class in org.apache.arrow.algorithm.sort
Default comparator for float type.
DefaultVectorComparators.Float8Comparator - Class in org.apache.arrow.algorithm.sort
Default comparator for double type.
DefaultVectorComparators.IntComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for 32-bit integers.
DefaultVectorComparators.IntervalDayComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for IntervalDay type.
DefaultVectorComparators.LongComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for long integers.
DefaultVectorComparators.NullComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for NullVector.
DefaultVectorComparators.RepeatedValueComparator<T extends ValueVector> - Class in org.apache.arrow.algorithm.sort
Default comparator for RepeatedValueVector.
DefaultVectorComparators.ShortComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for short integers.
DefaultVectorComparators.TimeMicroComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for TimeMicro type.
DefaultVectorComparators.TimeMilliComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for TimeMilli type.
DefaultVectorComparators.TimeNanoComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for TimeNano type.
DefaultVectorComparators.TimeSecComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for TimeSec type.
DefaultVectorComparators.TimeStampComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for TimeSec type.
DefaultVectorComparators.UInt1Comparator - Class in org.apache.arrow.algorithm.sort
Default comparator for unsigned bytes.
DefaultVectorComparators.UInt2Comparator - Class in org.apache.arrow.algorithm.sort
Default comparator for unsigned short integer.
DefaultVectorComparators.UInt4Comparator - Class in org.apache.arrow.algorithm.sort
Default comparator for unsigned integer.
DefaultVectorComparators.UInt8Comparator - Class in org.apache.arrow.algorithm.sort
Default comparator for unsigned long integer.
DefaultVectorComparators.VariableWidthComparator - Class in org.apache.arrow.algorithm.sort
Default comparator for VariableWidthVector.
DEFINITION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
delegate - Variable in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
 
Dense - Static variable in class org.apache.arrow.flatbuf.UnionMode
 
DenseArray - Static variable in class org.apache.arrow.flatbuf.DictionaryKind
 
DenseUnionHolder - Class in org.apache.arrow.vector.holders
ValueHolder for Dense Union Vectors.
DenseUnionHolder() - Constructor for class org.apache.arrow.vector.holders.DenseUnionHolder
 
DenseUnionReader - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template DenseUnionReader.java
DenseUnionReader(DenseUnionVector) - Constructor for class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
DenseUnionVector - Class in org.apache.arrow.vector.complex
 
DenseUnionVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.DenseUnionVector
 
DenseUnionWriter - Class in org.apache.arrow.vector.complex.impl
 
DenseUnionWriter(DenseUnionVector) - Constructor for class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
DenseUnionWriter(DenseUnionVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
DensityAwareVector - Interface in org.apache.arrow.vector
Vector that support density aware initial capacity settings.
deriveBuffer(ArrowBuf, long, long) - Method in class org.apache.arrow.memory.BufferLedger
Derive a new ArrowBuf from a given source ArrowBuf.
deriveBuffer(ArrowBuf, long, long) - Method in interface org.apache.arrow.memory.ReferenceManager
Derive a new ArrowBuf from a given source ArrowBuf.
description() - Method in class org.apache.arrow.flight.CallStatus
A description of the result.
DESCRIPTION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.ActionType
 
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.CancelFlightInfoRequest
Parse the serialized form of this protocol message.
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.CancelFlightInfoResult
Parse the serialized form of this protocol message.
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.FlightDescriptor
Parse the serialized form of this protocol message.
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.FlightEndpoint
Parse the serialized form of this protocol message.
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.FlightInfo
Parse the serialized form of this protocol message.
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.PollInfo
 
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.RenewFlightEndpointRequest
Parse the serialized form of this protocol message.
deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.Ticket
Parse the serialized form of this protocol message.
deserialize(ArrowType, String) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
Given saved metadata and the underlying storage type, construct a new instance of the user type.
deserialize(ByteBuffer) - Static method in class org.apache.arrow.vector.types.pojo.Schema
Deprecated.
deserialize(byte[], BufferAllocator) - Static method in class org.apache.arrow.vector.util.SchemaUtility
Deserialize Arrow schema from byte array.
deserializeDictionaryBatch(Message, ArrowBuf) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an ArrowDictionaryBatch from a dictionary batch Message and data in an ArrowBuf.
deserializeDictionaryBatch(MessageMetadataResult, ArrowBuf) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an ArrowDictionaryBatch from a dictionary batch Message and data in an ArrowBuf.
deserializeDictionaryBatch(ReadChannel, BufferAllocator) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an ArrowDictionaryBatch read from the input channel.
deserializeDictionaryBatch(ReadChannel, ArrowBlock, BufferAllocator) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes a DictionaryBatch knowing the size of the entire message up front.
deserializeMessage(ByteBuffer) - Static method in class org.apache.arrow.vector.types.pojo.Schema
Deserialize a schema that has been serialized as a message using Schema.serializeAsMessage().
deserializeMessageBatch(MessageChannelReader) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserialize a message that is either an ArrowDictionaryBatch or ArrowRecordBatch.
deserializeMessageBatch(ReadChannel, BufferAllocator) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserialize a message that is either an ArrowDictionaryBatch or ArrowRecordBatch.
deserializeRecordBatch(Message, ArrowBuf) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an ArrowRecordBatch from a record batch message and data in an ArrowBuf.
deserializeRecordBatch(ReadChannel, BufferAllocator) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an ArrowRecordBatch read from the input channel.
deserializeRecordBatch(ReadChannel, ArrowBlock, BufferAllocator) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an ArrowRecordBatch knowing the size of the entire message up front.
deserializeRecordBatch(RecordBatch, ArrowBuf) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an ArrowRecordBatch given the Flatbuffer metadata and in-memory body.
deserializeRecordBatch(MessageMetadataResult, ArrowBuf) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Reads a record batch based on the metadata in serializedMessage and the underlying data buffer.
deserializeSchema(Message) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an Arrow Schema object from a schema message.
deserializeSchema(ReadChannel) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an Arrow Schema read from the input channel.
deserializeSchema(MessageMetadataResult) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deserializes an Arrow Schema object from a MessageMetadataResult.
determineEndpoints(T, FlightDescriptor, Schema) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
Return a list of FlightEndpoints for the given request and FlightDescriptor.
dictionaries(int) - Method in class org.apache.arrow.flatbuf.Footer
 
dictionaries(Block, int) - Method in class org.apache.arrow.flatbuf.Footer
 
dictionaries - Variable in class org.apache.arrow.vector.ipc.ArrowReader
 
dictionariesLength() - Method in class org.apache.arrow.flatbuf.Footer
 
dictionariesVector() - Method in class org.apache.arrow.flatbuf.Footer
 
dictionariesVector(Block.Vector) - Method in class org.apache.arrow.flatbuf.Footer
 
dictionary() - Method in class org.apache.arrow.flatbuf.Field
Present only if the field is dictionary encoded.
dictionary(DictionaryEncoding) - Method in class org.apache.arrow.flatbuf.Field
 
Dictionary - Class in org.apache.arrow.vector.dictionary
A dictionary (integer to Value mapping) that is used to facilitate dictionary encoding compression.
Dictionary(FieldVector, DictionaryEncoding) - Constructor for class org.apache.arrow.vector.dictionary.Dictionary
 
DICTIONARY_REPLACEMENT - Static variable in class org.apache.arrow.flatbuf.Feature
The stream makes use of multiple full dictionaries with the same ID and assumes clients implement dictionary replacement correctly.
DictionaryBatch - Class in org.apache.arrow.flatbuf
For sending dictionary encoding information.
DictionaryBatch() - Constructor for class org.apache.arrow.flatbuf.DictionaryBatch
 
DictionaryBatch - Static variable in class org.apache.arrow.flatbuf.MessageHeader
 
DictionaryBatch.Vector - Class in org.apache.arrow.flatbuf
 
DictionaryBuilder<V extends ValueVector> - Interface in org.apache.arrow.algorithm.dictionary
A dictionary builder is intended for the scenario frequently encountered in practice: the dictionary is not known a priori, so it is generated dynamically.
DictionaryEncoder<E extends BaseIntVector,D extends ValueVector> - Interface in org.apache.arrow.algorithm.dictionary
A dictionary encoder translates one vector into another one based on a dictionary vector.
DictionaryEncoder - Class in org.apache.arrow.vector.dictionary
Encoder/decoder for Dictionary encoded ValueVector.
DictionaryEncoder(Dictionary, BufferAllocator) - Constructor for class org.apache.arrow.vector.dictionary.DictionaryEncoder
Construct an instance.
DictionaryEncoder(Dictionary, BufferAllocator, ArrowBufHasher) - Constructor for class org.apache.arrow.vector.dictionary.DictionaryEncoder
Construct an instance.
DictionaryEncoding - Class in org.apache.arrow.flatbuf
 
DictionaryEncoding() - Constructor for class org.apache.arrow.flatbuf.DictionaryEncoding
 
DictionaryEncoding - Class in org.apache.arrow.vector.types.pojo
A POJO representation of Arrow Dictionary metadata.
DictionaryEncoding(long, boolean, ArrowType.Int) - Constructor for class org.apache.arrow.vector.types.pojo.DictionaryEncoding
Constructs a new instance.
DictionaryEncoding.Vector - Class in org.apache.arrow.flatbuf
 
DictionaryHashTable - Class in org.apache.arrow.vector.dictionary
HashTable used for Dictionary encoding.
DictionaryHashTable(int, ValueVector, ArrowBufHasher) - Constructor for class org.apache.arrow.vector.dictionary.DictionaryHashTable
Constructs an empty map with the specified initial capacity and load factor.
DictionaryHashTable(ValueVector, ArrowBufHasher) - Constructor for class org.apache.arrow.vector.dictionary.DictionaryHashTable
 
DictionaryHashTable(ValueVector) - Constructor for class org.apache.arrow.vector.dictionary.DictionaryHashTable
 
dictionaryKind() - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
DictionaryKind - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- Dictionary encoding metadata Maintained for forwards compatibility, in the future Dictionaries might be explicit maps between integers and values allowing for non-contiguous index values
DictionaryProvider - Interface in org.apache.arrow.vector.dictionary
A manager for association of dictionary IDs to their corresponding Dictionary.
dictionaryProvider - Variable in class org.apache.arrow.vector.table.BaseTable
An optional DictionaryProvider.
DictionaryProvider.MapDictionaryProvider - Class in org.apache.arrow.vector.dictionary
Implementation of DictionaryProvider that is backed by a hash-map.
DictionaryUtility - Class in org.apache.arrow.vector.util
Utility methods for working with Dictionaries used in Dictionary encodings.
directAddVector(FieldVector) - Method in class org.apache.arrow.vector.complex.UnionVector
Directly put a vector to internalStruct without creating a new one with same type.
directBuffer() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
directBuffer(int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
directBuffer(int, int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
directBuffer(long, int) - Static method in class org.apache.arrow.memory.util.MemoryUtil
Create nio byte buffer.
directStruct() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
Returns a StructWriter, initializing it necessary from the constructor this instance was constructed with.
DIVIDE_BY_8_SHIFT_BITS - Static variable in class org.apache.arrow.vector.util.DataSizeRoundingUtil
The number of bits to shift for dividing by 8.
divideBy8Ceil(int) - Static method in class org.apache.arrow.vector.util.DataSizeRoundingUtil
A fast way to compute Math.ceil(input / 8.0).
divideBy8Ceil(long) - Static method in class org.apache.arrow.vector.util.DataSizeRoundingUtil
A fast way to compute Math.ceil(input / 8.0).
doAction(Action, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Performs an action on the Flight service.
doAction(FlightProducer.CallContext, Action, FlightProducer.StreamListener<Result>) - Method in interface org.apache.arrow.flight.FlightProducer
Generic handler for application-defined RPCs.
doAction(Flight.Action, StreamObserver<Flight.Result>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
Flight services can support an arbitrary number of simple actions in addition to the possible ListFlights, GetFlightInfo, DoGet, DoPut operations that are potentially available.
doAction(Flight.Action) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
Flight services can support an arbitrary number of simple actions in addition to the possible ListFlights, GetFlightInfo, DoGet, DoPut operations that are potentially available.
doAction(Flight.Action, StreamObserver<Flight.Result>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
Flight services can support an arbitrary number of simple actions in addition to the possible ListFlights, GetFlightInfo, DoGet, DoPut operations that are potentially available.
doAction(FlightProducer.CallContext, Action, FlightProducer.StreamListener<Result>) - Method in class org.apache.arrow.flight.NoOpFlightProducer
 
doAction(FlightProducer.CallContext, Action, FlightProducer.StreamListener<Result>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Performs the requested Flight SQL action.
doClientAuth(ClientAuthHandler, FlightServiceGrpc.FlightServiceStub) - Static method in class org.apache.arrow.flight.auth.ClientAuthWrapper
Do client auth for a client.
doClientHandshake(FlightServiceGrpc.FlightServiceStub) - Static method in class org.apache.arrow.flight.auth2.ClientHandshakeWrapper
Do handshake for a client.
doCompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.compression.Lz4CompressionCodec
 
doCompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.compression.ZstdCompressionCodec
 
doCompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.vector.compression.AbstractCompressionCodec
The method that actually performs the data compression.
doDecompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.compression.Lz4CompressionCodec
 
doDecompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.compression.ZstdCompressionCodec
 
doDecompress(BufferAllocator, ArrowBuf) - Method in class org.apache.arrow.vector.compression.AbstractCompressionCodec
The method that actually performs the data decompression.
doesBitmaskTranslateToEnum(ProtocolMessageEnum, long) - Static method in class org.apache.arrow.flight.sql.util.SqlInfoOptionsUtils
Returns whether the provided bitmask points to the provided ProtocolMessageEnum by comparing ProtocolMessageEnum.getNumber() with the respective bit index of the bitmask.
doesMaxRowSizeIncludeBlobs() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
doExchange(FlightDescriptor, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Initiate a bidirectional data exchange with the server.
doExchange(FlightProducer.CallContext, FlightStream, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.FlightProducer
 
doExchange(StreamObserver<Flight.FlightData>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
Open a bidirectional data channel for a given descriptor.
doExchange(StreamObserver<Flight.FlightData>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
Open a bidirectional data channel for a given descriptor.
doGet(Flight.Ticket, StreamObserver<Flight.FlightData>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
Retrieve a single stream associated with a particular descriptor associated with the referenced ticket.
doGet(Flight.Ticket) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
Retrieve a single stream associated with a particular descriptor associated with the referenced ticket.
doGet(Flight.Ticket, StreamObserver<Flight.FlightData>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
Retrieve a single stream associated with a particular descriptor associated with the referenced ticket.
doPut(StreamObserver<Flight.PutResult>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
Push a stream to the flight service associated with a particular flight stream.
doPut(StreamObserver<Flight.PutResult>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
Push a stream to the flight service associated with a particular flight stream.
DOUBLE - Static variable in class org.apache.arrow.flatbuf.Precision
 
DoubleConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume double type values from ResultSet.
DoubleConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.DoubleConsumer
 
doWork() - Method in class org.apache.arrow.vector.SchemaChangeCallBack
Sets the schema-changed state to true.
doWork() - Method in interface org.apache.arrow.vector.util.CallBack
 
Duration - Class in org.apache.arrow.flatbuf
 
Duration() - Constructor for class org.apache.arrow.flatbuf.Duration
 
Duration - Static variable in class org.apache.arrow.flatbuf.Type
 
duration(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
duration(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
duration() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
duration(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
duration() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
duration(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
duration(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
duration() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
duration() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
duration(String, TimeUnit) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
duration(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Duration(TimeUnit) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
Duration.Vector - Class in org.apache.arrow.flatbuf
 
DurationAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Duration Arrow types.
DurationAvaticaParameterConverter(ArrowType.Duration) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.DurationAvaticaParameterConverter
 
DurationComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.DurationComparator
 
DurationHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
DurationHolder() - Constructor for class org.apache.arrow.vector.holders.DurationHolder
 
DurationHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
DurationHolderReaderImpl(DurationHolder) - Constructor for class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
DurationReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
DurationReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
DurationReaderImpl(DurationVector) - Constructor for class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
DurationVector - Class in org.apache.arrow.vector
DurationVector implements a fixed width vector (8 bytes) of a configurable TimeUnit granularity duration values which could be null.
DurationVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.DurationVector
Instantiate a DurationVector.
DurationVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.DurationVector
Instantiate a DurationVector.
DurationWriter - Interface in org.apache.arrow.vector.complex.writer
 
DurationWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
DurationWriterImpl(DurationVector) - Constructor for class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 

E

EchoServer - Class in org.apache.arrow.tools
Simple server that echoes back data received.
EchoServer(int) - Constructor for class org.apache.arrow.tools.EchoServer
Constructs a new instance that binds to the given port.
EchoServer.ClientConnection - Class in org.apache.arrow.tools
Handler for each client connection to the server.
ElementAddressableVector - Interface in org.apache.arrow.vector
Vector for which each data element resides in a continuous memory region, so it can be pointed to by an ArrowBufPointer.
ElementAddressableVectorIterator<T extends ElementAddressableVector> - Class in org.apache.arrow.vector.util
Iterator for traversing elements of a ElementAddressableVector.
ElementAddressableVectorIterator(T) - Constructor for class org.apache.arrow.vector.util.ElementAddressableVectorIterator
Constructs an iterator for the ElementAddressableVector.
ElementAddressableVectorIterator(T, ArrowBufHasher) - Constructor for class org.apache.arrow.vector.util.ElementAddressableVectorIterator
Constructs an iterator for the ElementAddressableVector.
empty - Variable in class io.netty.buffer.PooledByteBufAllocatorL
 
empty() - Static method in class org.apache.arrow.flight.PutResult
Create an empty PutResult.
empty() - Method in interface org.apache.arrow.memory.AllocationManager.Factory
 
empty() - Method in class org.apache.arrow.memory.DefaultAllocationManagerFactory
 
empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.DenseUnionVector
 
empty(String, int, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.LargeListVector
 
empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.ListVector
 
empty(String, BufferAllocator, boolean) - Static method in class org.apache.arrow.vector.complex.MapVector
Construct an empty MapVector with no data.
empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.StructVector
 
empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.UnionVector
 
EMPTY_BYTES - Static variable in class org.apache.arrow.vector.util.ReusableByteArray
 
EMPTY_LIST_INSTANCE - Static variable in class org.apache.arrow.vector.complex.impl.NullReader
 
EMPTY_STRUCT_INSTANCE - Static variable in class org.apache.arrow.vector.complex.impl.NullReader
 
emptyByteArray - Static variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
emptyByteArray - Static variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
EmptyValuePopulator - Class in org.apache.arrow.vector.complex
A helper class that is used to track and populate empty values in repeated value vectors.
EmptyValuePopulator(UInt4Vector) - Constructor for class org.apache.arrow.vector.complex.EmptyValuePopulator
 
emptyWithDuplicates(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
emptyWithDuplicates(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.StructVector
 
encode(D, E) - Method in interface org.apache.arrow.algorithm.dictionary.DictionaryEncoder
Translates an input vector into an output vector.
encode(D, E) - Method in class org.apache.arrow.algorithm.dictionary.HashTableDictionaryEncoder
Encodes an input vector by a hash table.
encode(D, E) - Method in class org.apache.arrow.algorithm.dictionary.LinearDictionaryEncoder
Encodes an input vector by linear search.
encode(D, E) - Method in class org.apache.arrow.algorithm.dictionary.SearchDictionaryEncoder
Encodes an input vector by binary search.
encode(ValueVector, Dictionary) - Static method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
Dictionary encodes a vector with a provided dictionary.
encode(ValueVector) - Method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
Encodes a vector with the built hash table in this encoder.
encode(StructVector, Map<Integer, Long>) - Method in class org.apache.arrow.vector.dictionary.StructSubfieldEncoder
Dictionary encodes subfields for complex vector with a provided dictionary.
encode(String, long) - Method in class org.apache.arrow.vector.table.BaseTable
Returns a ValueVector containing the encoded version of the vector with the given name.
encode(String) - Static method in class org.apache.arrow.vector.util.Text
Converts the provided String to bytes using the UTF-8 encoding.
encode(String, boolean) - Static method in class org.apache.arrow.vector.util.Text
Converts the provided String to bytes using the UTF-8 encoding.
encodeListSubField(BaseListVector) - Method in class org.apache.arrow.vector.dictionary.ListSubfieldEncoder
Dictionary encodes subfields for complex vector with a provided dictionary.
end() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
end() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
end() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
end() - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
Finish writing to the list or struct.
end() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
end() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
end() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
end() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
end() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
end() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
end - Variable in class org.apache.arrow.vector.holders.LargeVarBinaryHolder
 
end - Variable in class org.apache.arrow.vector.holders.LargeVarCharHolder
 
end - Variable in class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
 
end - Variable in class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
 
end - Variable in class org.apache.arrow.vector.holders.NullableVarBinaryHolder
 
end - Variable in class org.apache.arrow.vector.holders.NullableVarCharHolder
 
end - Variable in class org.apache.arrow.vector.holders.RepeatedListHolder
 
end - Variable in class org.apache.arrow.vector.holders.RepeatedStructHolder
 
end - Variable in class org.apache.arrow.vector.holders.VarBinaryHolder
 
end - Variable in class org.apache.arrow.vector.holders.VarCharHolder
 
end() - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
END_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
END_SAVEPOINT_RELEASE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
Release the savepoint.
END_SAVEPOINT_ROLLBACK_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
Roll back to a savepoint.
END_SAVEPOINT_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
END_SAVEPOINT_UNSPECIFIED = 0;
END_TRANSACTION_COMMIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
Commit the transaction.
END_TRANSACTION_ROLLBACK_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
Roll back the transaction.
END_TRANSACTION_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
END_TRANSACTION_UNSPECIFIED = 0;
endBinary(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Binary
 
endBinaryView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.BinaryView
 
endBodyCompression(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
endBool(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Bool
 
endDate(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Date
 
endDecimal(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Decimal
 
endDictionaryBatch(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
endDictionaryEncoding(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
endDuration(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Duration
 
endEntry() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
Complete the map entry.
endEntry() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
endEntry() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.MapWriter
 
endField(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Field
 
endFixedSizeBinary(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
endFixedSizeList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.FixedSizeList
 
endFloatingPoint(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.FloatingPoint
 
endFooter(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Footer
 
Endianness - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- Endianness of the platform producing the data
endianness() - Method in class org.apache.arrow.flatbuf.Schema
endianness of the buffer it is Little Endian by default if endianness doesn't match the underlying system then the vectors need to be converted
endInt(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Int
 
endInternal(WriteChannel) - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
 
endInternal(WriteChannel) - Method in class org.apache.arrow.vector.ipc.ArrowStreamWriter
 
endInternal(WriteChannel) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
endInterval(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Interval
 
endKeyValue(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.KeyValue
 
endLargeBinary(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeBinary
 
endLargeList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeList
 
endLargeListView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeListView
 
endLargeUtf8(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeUtf8
 
endList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.List
 
endList() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
endList() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
endList() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
endList() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
endList() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
endList() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
endListView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.ListView
 
endMap(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Map
 
endMap() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
Complete the map.
endMap() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
endMap() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.MapWriter
 
endMessage(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Message
 
endNull(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Null
 
ENDPOINT_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
ENDPOINT_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
endRecordBatch(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
endRunEndEncoded(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.RunEndEncoded
 
endSavepoint(FlightSql.ActionEndSavepointRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
endSavepoint(FlightSql.ActionEndSavepointRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Release or roll back to a savepoint.
endSchema(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Schema
 
endSparseMatrixIndexCSX(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
endSparseTensor(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
endSparseTensorIndexCOO(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
endSparseTensorIndexCSF(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
endStruct_(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Struct_
 
endTensor(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Tensor
 
endTensorDim(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.TensorDim
 
endTime(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Time
 
endTimestamp(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Timestamp
 
endTransaction(FlightSql.ActionEndTransactionRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
endTransaction(FlightSql.ActionEndTransactionRequest, FlightProducer.CallContext, FlightProducer.StreamListener<Result>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Commit or roll back to a transaction.
endUnion(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Union
 
endUtf8(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Utf8
 
endUtf8View(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Utf8View
 
endValue(int, long) - Method in class org.apache.arrow.vector.complex.LargeListVector
End the current value.
endValue(int, int) - Method in class org.apache.arrow.vector.complex.ListVector
End the current value.
enqueue(Collection<CloseableEndpointStreamPair>) - Method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Readily adds given FlightStreams to the queue.
enqueue(CloseableEndpointStreamPair) - Method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Adds given FlightStream to the queue.
ensureCapacity(VectorSchemaRoot, int) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Ensure capacity for BaseFixedWidthVector.
ensureDictionariesWritten(DictionaryProvider, Set<Long>) - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
 
ensureDictionariesWritten(DictionaryProvider, Set<Long>) - Method in class org.apache.arrow.vector.ipc.ArrowStreamWriter
 
ensureDictionariesWritten(DictionaryProvider, Set<Long>) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
Write dictionaries after schema and before recordBatches, dictionaries won't be written if empty stream (only has schema data in IPC).
ensureInitialized() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Initialize if not done previously.
equal(ArrowBuf, long, long, ArrowBuf, long, long) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
Helper function to check for equality of bytes in two ArrowBufs.
equals(Object) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
equals(Object) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcTime
 
equals(Object) - Method in class org.apache.arrow.flight.CancelFlightInfoResult
 
equals(Object) - Method in class org.apache.arrow.flight.FlightDescriptor
 
equals(Object) - Method in class org.apache.arrow.flight.FlightEndpoint
 
equals(Object) - Method in class org.apache.arrow.flight.FlightInfo
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.Action
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.Location
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.Result
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
equals(Object) - Method in class org.apache.arrow.flight.Location
 
equals(Object) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
equals(Object) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
equals(Object) - Method in class org.apache.arrow.flight.PollInfo
 
equals(Object) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.SubstraitPlan
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
equals(Object) - Method in class org.apache.arrow.flight.Ticket
 
equals(Object) - Method in class org.apache.arrow.memory.ArrowBuf
 
equals(Object) - Method in class org.apache.arrow.memory.util.ArrowBufPointer
 
equals(Object) - Method in class org.apache.arrow.memory.util.hash.MurmurHasher
 
equals(Object) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
 
equals(Object) - Method in class org.apache.arrow.vector.BufferLayout
 
equals(ValueVector) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
Check type equals without passing IN param in VectorVisitor.
equals(Object) - Method in class org.apache.arrow.vector.dictionary.Dictionary
 
equals(Object) - Method in class org.apache.arrow.vector.ipc.message.ArrowBlock
 
equals(Object) - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
 
equals(Object) - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
equals(Object) - Method in class org.apache.arrow.vector.PeriodDuration
 
equals(Object) - Method in class org.apache.arrow.vector.TypeLayout
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.DictionaryEncoding
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.Field
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
equals(Object) - Method in class org.apache.arrow.vector.types.pojo.Schema
 
equals(Object) - Method in class org.apache.arrow.vector.util.ReusableByteArray
 
equals(Object) - Method in class org.apache.arrow.vector.util.Text
 
equals(VectorSchemaRoot) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Determine if two VectorSchemaRoots are exactly equal.
error(Throwable) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Indicate an error to the client.
ErrorFlightMetadata - Class in org.apache.arrow.flight
metadata container specific to the binary metadata held in the grpc trailer.
ErrorFlightMetadata() - Constructor for class org.apache.arrow.flight.ErrorFlightMetadata
 
execute() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFlightStreamResultSet
 
execute() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcVectorSchemaRootResultSet
 
execute(Meta.StatementHandle, List<TypedValue>, long) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
execute(Meta.StatementHandle, List<TypedValue>, int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
execute(Runnable) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
execute(String, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute a query on the server.
execute(String, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute a query on the server.
execute(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Executes the prepared statement query on the server.
execute() - Method in class org.apache.arrow.maven.plugins.BaseModuleInfoCompilerPlugin
 
execute() - Method in class org.apache.arrow.maven.plugins.HelpMojo
executeApp(CommandLine) - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
Calls FlightSqlClientDemoApp.createFlightSqlClient(String, int) in order to create a FlightSqlClient to be used in future calls, and then calls FlightSqlClientDemoApp.executeCommand(CommandLine) to execute the command parsed at execution.
executeBatch(Meta.StatementHandle, List<List<TypedValue>>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
executeCommand(CommandLine) - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
Parses the "command" CLI argument and redirects to the appropriate method.
executeFlightInfoQuery() - Method in interface org.apache.arrow.driver.jdbc.ArrowFlightInfoStatement
Executes the query this Statement is holding.
executeFlightInfoQuery() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightPreparedStatement
 
executeFlightInfoQuery() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightStatement
 
executeQuery() - Method in interface org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.PreparedStatement
executeSubstrait(FlightSqlClient.SubstraitPlan, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute a Substrait plan on the server.
executeSubstrait(FlightSqlClient.SubstraitPlan, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute a Substrait plan on the server.
executeSubstraitUpdate(FlightSqlClient.SubstraitPlan, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute an update query on the server.
executeSubstraitUpdate(FlightSqlClient.SubstraitPlan, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute an update query on the server.
executeUpdate() - Method in interface org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.PreparedStatement
Executes a Meta.StatementType.UPDATE query.
executeUpdate(String, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute an update query on the server.
executeUpdate(String, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Execute an update query on the server.
executeUpdate(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Executes the prepared statement update on the server.
executor(ExecutorService) - Method in class org.apache.arrow.flight.FlightServer.Builder
Set the executor used by the server.
ExpandableByteBuf - Class in io.netty.buffer
Allows us to decorate ArrowBuf to make it expandable so that we can use them in the context of the Netty framework (thus supporting RPC level memory accounting).
ExpandableByteBuf(ByteBuf, BufferAllocator) - Constructor for class io.netty.buffer.ExpandableByteBuf
 
experimental - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql
extend .google.protobuf.MessageOptions { ...
EXPERIMENTAL_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql
 
EXPIRATION_TIME_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
EXPIRATION_TIME_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.PollInfo
 
EXPRESSION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.Criteria
 
EXTENSION_METADATA_KEY_METADATA - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
The field metadata key storing metadata for the extension type.
EXTENSION_METADATA_KEY_NAME - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
The field metadata key storing the name of the extension type.
extensionEquals(ArrowType.ExtensionType) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
Check equality of this type to another user-defined type.
extensionName() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
The name of this user-defined type.
ExtensionType() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
 
ExtensionTypeRegistry - Class in org.apache.arrow.vector.types.pojo
A registry of recognized extension types.
ExtensionTypeRegistry() - Constructor for class org.apache.arrow.vector.types.pojo.ExtensionTypeRegistry
 
ExtensionTypeVector<T extends ValueVector & FieldVector> - Class in org.apache.arrow.vector
A vector that wraps an underlying vector, used to help implement extension types.
ExtensionTypeVector(String, BufferAllocator, T) - Constructor for class org.apache.arrow.vector.ExtensionTypeVector
Instantiate an extension type vector.
ExtensionTypeVector(Field, BufferAllocator, T) - Constructor for class org.apache.arrow.vector.ExtensionTypeVector
Instantiate an extension type vector.
extractUncompressedBuffer(ArrowBuf) - Static method in class org.apache.arrow.vector.compression.CompressionUtil
Process decompression by slicing the buffer that contains the uncompressed bytes.

F

Factory(ClientHeaderHandler) - Constructor for class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware.Factory
Construct a factory with the given header handler.
Factory(CallHeaderAuthenticator) - Constructor for class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware.Factory
Construct a factory with the given auth handler.
Factory() - Constructor for class org.apache.arrow.flight.client.ClientCookieMiddleware.Factory
 
Factory() - Constructor for class org.apache.arrow.flight.ServerHeaderMiddleware.Factory
Construct a factory for receiving call headers.
FACTORY - Static variable in class org.apache.arrow.memory.DefaultAllocationManagerFactory
 
FACTORY - Static variable in class org.apache.arrow.memory.NettyAllocationManager
 
FACTORY - Static variable in class org.apache.arrow.memory.UnsafeAllocationManager
 
Factory() - Constructor for class org.apache.arrow.vector.compression.NoCompressionCodec.Factory
 
FBSerializable - Interface in org.apache.arrow.vector.ipc.message
Interface for serializing to FlatBuffers.
FBSerializables - Class in org.apache.arrow.vector.ipc.message
Utility methods for FBSerializables.
Feature - Class in org.apache.arrow.flatbuf
Represents Arrow Features that might not have full support within implementations.
features(int) - Method in class org.apache.arrow.flatbuf.Schema
Features used in the stream/file.
featuresAsByteBuffer() - Method in class org.apache.arrow.flatbuf.Schema
 
featuresInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.Schema
 
featuresLength() - Method in class org.apache.arrow.flatbuf.Schema
 
featuresVector() - Method in class org.apache.arrow.flatbuf.Schema
 
featuresVector(LongVector) - Method in class org.apache.arrow.flatbuf.Schema
 
fetch(Meta.StatementHandle, long, int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
fetchSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Get the schema of the result set (should be identical to FlightSqlClient.PreparedStatement.getResultSetSchema()).
Field - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- A field represents a named column in a record / row batch or child of a nested type.
Field() - Constructor for class org.apache.arrow.flatbuf.Field
 
field - Variable in class org.apache.arrow.vector.BaseFixedWidthVector
 
field - Variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
field - Variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
field - Variable in class org.apache.arrow.vector.complex.ListVector
 
field - Variable in class org.apache.arrow.vector.complex.NonNullableStructVector
 
field - Variable in class org.apache.arrow.vector.NullVector
 
Field - Class in org.apache.arrow.vector.types.pojo
A POJO abstraction for the Flatbuffer description of Vector Type.
Field(String, FieldType, List<Field>) - Constructor for class org.apache.arrow.vector.types.pojo.Field
 
Field.Vector - Class in org.apache.arrow.flatbuf
 
fieldNameIterator() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
FieldNode - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- Data structures for describing a table row batch (a collection of equal-length Arrow arrays) Metadata about a field at some level of a nested type tree (but not its children).
FieldNode() - Constructor for class org.apache.arrow.flatbuf.FieldNode
 
FieldNode.Vector - Class in org.apache.arrow.flatbuf
 
fieldReader - Variable in class org.apache.arrow.vector.BaseValueVector
 
FieldReader - Interface in org.apache.arrow.vector.complex.reader
Composite of all Reader types (e.g.
fields(int) - Method in class org.apache.arrow.flatbuf.Schema
 
fields(Field, int) - Method in class org.apache.arrow.flatbuf.Schema
 
fieldsLength() - Method in class org.apache.arrow.flatbuf.Schema
 
fieldsVector() - Method in class org.apache.arrow.flatbuf.Schema
 
fieldsVector(Field.Vector) - Method in class org.apache.arrow.flatbuf.Schema
 
FieldType - Class in org.apache.arrow.vector.types.pojo
POJO representation of an Arrow field type.
FieldType(boolean, ArrowType, DictionaryEncoding) - Constructor for class org.apache.arrow.vector.types.pojo.FieldType
 
FieldType(boolean, ArrowType, DictionaryEncoding, Map<String, String>) - Constructor for class org.apache.arrow.vector.types.pojo.FieldType
Constructs a new instance.
FieldVector - Interface in org.apache.arrow.vector
A vector corresponding to a Field in the schema.
fieldVectors - Variable in class org.apache.arrow.vector.table.BaseTable
The field vectors holding the data in this table.
fieldVectorsMap - Variable in class org.apache.arrow.vector.table.BaseTable
A map of Fields to FieldVectors used to select Fields.
FieldWriter - Interface in org.apache.arrow.vector.complex.writer
Composite of all writer types.
FileRoundtrip - Class in org.apache.arrow.tools
Application that verifies data can be round-tripped through a file.
FileToStream - Class in org.apache.arrow.tools
Converts an Arrow file to an Arrow stream.
fillEmpties(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Create holes in the vector upto the given index (exclusive).
fillEmpties(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Create holes in the vector upto the given index (exclusive).
fillHoles(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
fillHoles(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
finalizeHashCode(int, long) - Static method in class org.apache.arrow.memory.util.hash.MurmurHasher
Finalizing the hash code.
finalizeHashCode(int) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
 
find(String) - Method in class org.apache.arrow.vector.util.Text
 
find(String, int) - Method in class org.apache.arrow.vector.util.Text
Finds any occurrence of what in the backing buffer, starting as position start.
findField(List<Field>, String) - Static method in class org.apache.arrow.vector.types.pojo.Schema
Search for a field by name in given the list of fields.
findField(String) - Method in class org.apache.arrow.vector.types.pojo.Schema
Search for a field by name in this Schema.
findPositionInPartialSumVector(BaseIntVector, long) - Static method in class org.apache.arrow.algorithm.misc.PartialSumUtils
Given a value and a partial sum vector, finds its position in the partial sum vector.
finishFooterBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
finishMessageBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Message
 
finishSchemaBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
finishSizePrefixedFooterBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
finishSizePrefixedMessageBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Message
 
finishSizePrefixedSchemaBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
finishSizePrefixedSparseTensorBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
finishSizePrefixedTensorBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
finishSparseTensorBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
finishTensorBuffer(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
FixedDecimalConsumer(DecimalVector, int) - Constructor for class org.apache.arrow.consumers.logical.AvroDecimalConsumer.FixedDecimalConsumer
Instantiate a FixedDecimalConsumer.
FixedSizeBinary - Class in org.apache.arrow.flatbuf
 
FixedSizeBinary() - Constructor for class org.apache.arrow.flatbuf.FixedSizeBinary
 
FixedSizeBinary - Static variable in class org.apache.arrow.flatbuf.Type
 
fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
fixedSizeBinary() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
fixedSizeBinary(String, int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
fixedSizeBinary(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
FixedSizeBinary(int) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
FixedSizeBinary.Vector - Class in org.apache.arrow.flatbuf
 
FixedSizeBinaryAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for FixedSizeBinary Arrow types.
FixedSizeBinaryAvaticaParameterConverter(ArrowType.FixedSizeBinary) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.FixedSizeBinaryAvaticaParameterConverter
 
FixedSizeBinaryBinder - Class in org.apache.arrow.adapter.jdbc.binder
A binder for fixed-width binary types.
FixedSizeBinaryBinder(FixedSizeBinaryVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.FixedSizeBinaryBinder
Create a binder for the given vector using the given JDBC type for null values.
FixedSizeBinaryComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeBinaryComparator
 
FixedSizeBinaryHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
FixedSizeBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
 
FixedSizeBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
FixedSizeBinaryHolderReaderImpl(FixedSizeBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
FixedSizeBinaryReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
FixedSizeBinaryReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
FixedSizeBinaryReaderImpl(FixedSizeBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
FixedSizeBinaryVector - Class in org.apache.arrow.vector
FixedSizeBinaryVector implements a fixed width vector of binary values which could be null.
FixedSizeBinaryVector(String, BufferAllocator, int) - Constructor for class org.apache.arrow.vector.FixedSizeBinaryVector
Instantiate a FixedSizeBinaryVector.
FixedSizeBinaryVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.FixedSizeBinaryVector
Instantiate a FixedSizeBinaryVector.
FixedSizeBinaryVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.FixedSizeBinaryVector
Instantiate a FixedSizeBinaryVector.
FixedSizeBinaryWriter - Interface in org.apache.arrow.vector.complex.writer
 
FixedSizeBinaryWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
FixedSizeBinaryWriterImpl(FixedSizeBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
FixedSizeList - Class in org.apache.arrow.flatbuf
 
FixedSizeList() - Constructor for class org.apache.arrow.flatbuf.FixedSizeList
 
FixedSizeList - Static variable in class org.apache.arrow.flatbuf.Type
 
FixedSizeList(int) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
FixedSizeList.Vector - Class in org.apache.arrow.flatbuf
 
FixedSizeListAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for FixedSizeList Arrow types.
FixedSizeListAvaticaParameterConverter(ArrowType.FixedSizeList) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.FixedSizeListAvaticaParameterConverter
 
FixedSizeListComparator(VectorValueComparator<T>) - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.FixedSizeListComparator
 
FixedSizeListVector - Class in org.apache.arrow.vector.complex
A ListVector where every list value is of the same size.
FixedSizeListVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.FixedSizeListVector
Creates a new instance.
FixedSizeListVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.FixedSizeListVector
Creates a new instance.
FixedWidthInPlaceVectorSorter<V extends BaseFixedWidthVector> - Class in org.apache.arrow.algorithm.sort
Default in-place sorter for fixed-width vectors.
FixedWidthInPlaceVectorSorter() - Constructor for class org.apache.arrow.algorithm.sort.FixedWidthInPlaceVectorSorter
 
FixedWidthOutOfPlaceVectorSorter<V extends BaseFixedWidthVector> - Class in org.apache.arrow.algorithm.sort
Default out-of-place sorter for fixed-width vectors.
FixedWidthOutOfPlaceVectorSorter() - Constructor for class org.apache.arrow.algorithm.sort.FixedWidthOutOfPlaceVectorSorter
 
FixedWidthVector - Interface in org.apache.arrow.vector
Interface for all fixed width ElementAddressableVector (e.g.
FK_CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
FK_DB_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
FK_TABLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
Flight - Class in org.apache.arrow.flight.impl
 
Flight.Action - Class in org.apache.arrow.flight.impl
An opaque action specific for the service.
Flight.Action.Builder - Class in org.apache.arrow.flight.impl
An opaque action specific for the service.
Flight.ActionOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.ActionType - Class in org.apache.arrow.flight.impl
Describes an available action, including both the name used for execution along with a short description of the purpose of the action.
Flight.ActionType.Builder - Class in org.apache.arrow.flight.impl
Describes an available action, including both the name used for execution along with a short description of the purpose of the action.
Flight.ActionTypeOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.BasicAuth - Class in org.apache.arrow.flight.impl
A message for doing simple auth.
Flight.BasicAuth.Builder - Class in org.apache.arrow.flight.impl
A message for doing simple auth.
Flight.BasicAuthOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.CancelFlightInfoRequest - Class in org.apache.arrow.flight.impl
The request of the CancelFlightInfo action.
Flight.CancelFlightInfoRequest.Builder - Class in org.apache.arrow.flight.impl
The request of the CancelFlightInfo action.
Flight.CancelFlightInfoRequestOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.CancelFlightInfoResult - Class in org.apache.arrow.flight.impl
The result of the CancelFlightInfo action.
Flight.CancelFlightInfoResult.Builder - Class in org.apache.arrow.flight.impl
The result of the CancelFlightInfo action.
Flight.CancelFlightInfoResultOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.CancelStatus - Enum in org.apache.arrow.flight.impl
The result of a cancel operation.
Flight.Criteria - Class in org.apache.arrow.flight.impl
A service specific expression that can be used to return a limited set of available Arrow Flight streams.
Flight.Criteria.Builder - Class in org.apache.arrow.flight.impl
A service specific expression that can be used to return a limited set of available Arrow Flight streams.
Flight.CriteriaOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.Empty - Class in org.apache.arrow.flight.impl
Protobuf type arrow.flight.protocol.Empty
Flight.Empty.Builder - Class in org.apache.arrow.flight.impl
Protobuf type arrow.flight.protocol.Empty
Flight.EmptyOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.FlightData - Class in org.apache.arrow.flight.impl
A batch of Arrow data as part of a stream of batches.
Flight.FlightData.Builder - Class in org.apache.arrow.flight.impl
A batch of Arrow data as part of a stream of batches.
Flight.FlightDataOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.FlightDescriptor - Class in org.apache.arrow.flight.impl
The name or tag for a Flight.
Flight.FlightDescriptor.Builder - Class in org.apache.arrow.flight.impl
The name or tag for a Flight.
Flight.FlightDescriptor.DescriptorType - Enum in org.apache.arrow.flight.impl
Describes what type of descriptor is defined.
Flight.FlightDescriptorOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.FlightEndpoint - Class in org.apache.arrow.flight.impl
A particular stream or split associated with a flight.
Flight.FlightEndpoint.Builder - Class in org.apache.arrow.flight.impl
A particular stream or split associated with a flight.
Flight.FlightEndpointOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.FlightInfo - Class in org.apache.arrow.flight.impl
The access coordinates for retrieval of a dataset.
Flight.FlightInfo.Builder - Class in org.apache.arrow.flight.impl
The access coordinates for retrieval of a dataset.
Flight.FlightInfoOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.HandshakeRequest - Class in org.apache.arrow.flight.impl
The request that a client provides to a server on handshake.
Flight.HandshakeRequest.Builder - Class in org.apache.arrow.flight.impl
The request that a client provides to a server on handshake.
Flight.HandshakeRequestOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.HandshakeResponse - Class in org.apache.arrow.flight.impl
Protobuf type arrow.flight.protocol.HandshakeResponse
Flight.HandshakeResponse.Builder - Class in org.apache.arrow.flight.impl
Protobuf type arrow.flight.protocol.HandshakeResponse
Flight.HandshakeResponseOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.Location - Class in org.apache.arrow.flight.impl
A location where a Flight service will accept retrieval of a particular stream given a ticket.
Flight.Location.Builder - Class in org.apache.arrow.flight.impl
A location where a Flight service will accept retrieval of a particular stream given a ticket.
Flight.LocationOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.PollInfo - Class in org.apache.arrow.flight.impl
The information to process a long-running query.
Flight.PollInfo.Builder - Class in org.apache.arrow.flight.impl
The information to process a long-running query.
Flight.PollInfoOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.PutResult - Class in org.apache.arrow.flight.impl
The response message associated with the submission of a DoPut.
Flight.PutResult.Builder - Class in org.apache.arrow.flight.impl
The response message associated with the submission of a DoPut.
Flight.PutResultOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.RenewFlightEndpointRequest - Class in org.apache.arrow.flight.impl
The request of the RenewFlightEndpoint action.
Flight.RenewFlightEndpointRequest.Builder - Class in org.apache.arrow.flight.impl
The request of the RenewFlightEndpoint action.
Flight.RenewFlightEndpointRequestOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.Result - Class in org.apache.arrow.flight.impl
An opaque result returned after executing an action.
Flight.Result.Builder - Class in org.apache.arrow.flight.impl
An opaque result returned after executing an action.
Flight.ResultOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.SchemaResult - Class in org.apache.arrow.flight.impl
Wrap the result of a getSchema call
Flight.SchemaResult.Builder - Class in org.apache.arrow.flight.impl
Wrap the result of a getSchema call
Flight.SchemaResultOrBuilder - Interface in org.apache.arrow.flight.impl
 
Flight.Ticket - Class in org.apache.arrow.flight.impl
An opaque identifier that the service can use to retrieve a particular portion of a stream.
Flight.Ticket.Builder - Class in org.apache.arrow.flight.impl
An opaque identifier that the service can use to retrieve a particular portion of a stream.
Flight.TicketOrBuilder - Interface in org.apache.arrow.flight.impl
 
FLIGHT_DESCRIPTOR_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightData
 
FLIGHT_DESCRIPTOR_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
FLIGHT_DESCRIPTOR_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.PollInfo
 
FLIGHT_SQL_ACTIONS - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_BEGIN_SAVEPOINT - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_BEGIN_TRANSACTION - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_CANCEL_QUERY - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_CLOSE_PREPARED_STATEMENT - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_CREATE_PREPARED_STATEMENT - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_CREATE_PREPARED_SUBSTRAIT_PLAN - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_END_SAVEPOINT - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_END_TRANSACTION - Static variable in class org.apache.arrow.flight.sql.FlightSqlUtils
 
FLIGHT_SQL_SERVER_ARROW_VERSION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with the Arrow format version of the Flight SQL Server.
FLIGHT_SQL_SERVER_CANCEL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether the Flight SQL Server supports explicit query cancellation (the CancelQuery action).
FLIGHT_SQL_SERVER_NAME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with the name of the Flight SQL Server.
FLIGHT_SQL_SERVER_READ_ONLY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether the Flight SQL Server is read only.
FLIGHT_SQL_SERVER_SQL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether the Flight SQL Server supports executing SQL queries.
FLIGHT_SQL_SERVER_STATEMENT_TIMEOUT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves an int32 indicating the timeout (in milliseconds) for prepared statement handles.
FLIGHT_SQL_SERVER_SUBSTRAIT_MAX_VERSION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a string value indicating the maximum supported Substrait version, or null if Substrait is not supported.
FLIGHT_SQL_SERVER_SUBSTRAIT_MIN_VERSION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a string value indicating the minimum supported Substrait version, or null if Substrait is not supported.
FLIGHT_SQL_SERVER_SUBSTRAIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether the Flight SQL Server supports executing Substrait plans.
FLIGHT_SQL_SERVER_TRANSACTION_TIMEOUT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves an int32 indicating the timeout (in milliseconds) for transactions, since transactions are not tied to a connection.
FLIGHT_SQL_SERVER_TRANSACTION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves an int32 indicating whether the Flight SQL Server supports the BeginTransaction/EndTransaction/BeginSavepoint/EndSavepoint actions.
FLIGHT_SQL_SERVER_VERSION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with the native version of the Flight SQL Server.
FlightCallHeaders - Class in org.apache.arrow.flight
An implementation of the Flight headers interface for headers.
FlightCallHeaders() - Constructor for class org.apache.arrow.flight.FlightCallHeaders
 
FlightClient - Class in org.apache.arrow.flight
Client for Flight services.
FlightClient.Builder - Class in org.apache.arrow.flight
A builder for Flight clients.
FlightClient.ClientStreamListener - Interface in org.apache.arrow.flight
Interface for writers to an Arrow data stream.
FlightClient.ExchangeReaderWriter - Class in org.apache.arrow.flight
A pair of a reader and a writer for a DoExchange call.
FlightClient.PutListener - Interface in org.apache.arrow.flight
A handler for server-sent application metadata messages during a Flight DoPut operation.
FlightClientMiddleware - Interface in org.apache.arrow.flight
Client-side middleware for Flight.
FlightClientMiddleware.Factory - Interface in org.apache.arrow.flight
A factory for client middleware instances.
FlightConstants - Interface in org.apache.arrow.flight
String constants relevant to flight implementations.
FlightDescriptor - Class in org.apache.arrow.flight
An identifier for a particular set of data.
FlightEndpoint - Class in org.apache.arrow.flight
POJO to convert to/from the underlying protobuf FlightEndpoint.
FlightEndpoint(Ticket, Location...) - Constructor for class org.apache.arrow.flight.FlightEndpoint
Constructs a new endpoint with no expiration time.
FlightEndpoint(Ticket, Instant, Location...) - Constructor for class org.apache.arrow.flight.FlightEndpoint
Constructs a new endpoint with an expiration time.
FlightEndpoint.Builder - Class in org.apache.arrow.flight
Builder for FlightEndpoint.
FlightEndpointDataQueue - Class in org.apache.arrow.driver.jdbc.utils
Auxiliary class used to handle consuming of multiple FlightStream.
FlightEndpointDataQueue(CompletionService<CloseableEndpointStreamPair>) - Constructor for class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Instantiate a new FlightStreamQueue.
FlightEndpointListener - Class in org.apache.arrow.flight.sql
Typed StreamListener for renewFlightEndpoint.
FlightGrpcUtils - Class in org.apache.arrow.flight
Exposes Flight GRPC service & client.
FlightInfo - Class in org.apache.arrow.flight
A POJO representation of a FlightInfo, metadata associated with a set of data records.
FlightInfo(Schema, FlightDescriptor, List<FlightEndpoint>, long, long) - Constructor for class org.apache.arrow.flight.FlightInfo
Constructs a new instance.
FlightInfo(Schema, FlightDescriptor, List<FlightEndpoint>, long, long, IpcOption) - Constructor for class org.apache.arrow.flight.FlightInfo
Constructs a new instance.
FlightInfo(Schema, FlightDescriptor, List<FlightEndpoint>, long, long, boolean, IpcOption) - Constructor for class org.apache.arrow.flight.FlightInfo
Constructs a new instance.
FlightInfo(Schema, FlightDescriptor, List<FlightEndpoint>, long, long, boolean, IpcOption, byte[]) - Constructor for class org.apache.arrow.flight.FlightInfo
Constructs a new instance.
FlightInfo.Builder - Class in org.apache.arrow.flight
Builder for FlightInfo.
FlightMethod - Enum in org.apache.arrow.flight
All the RPC methods available in Flight.
FlightProducer - Interface in org.apache.arrow.flight
API to Implement an Arrow Flight producer.
FlightProducer.CallContext - Interface in org.apache.arrow.flight
Call-specific context.
FlightProducer.ServerStreamListener - Interface in org.apache.arrow.flight
An interface for sending Arrow data back to a client.
FlightProducer.StreamListener<T> - Interface in org.apache.arrow.flight
Callbacks for pushing objects to a receiver.
FlightRuntimeException - Exception in org.apache.arrow.flight
An exception raised from a Flight RPC.
FlightServer - Class in org.apache.arrow.flight
Generic server of flight data that is customized via construction with delegate classes for the actual logic.
FlightServer.Builder - Class in org.apache.arrow.flight
A builder for Flight servers.
FlightServerMiddleware - Interface in org.apache.arrow.flight
Server-side middleware for Flight calls.
FlightServerMiddleware.Factory<T extends FlightServerMiddleware> - Interface in org.apache.arrow.flight
A factory for Flight server middleware.
FlightServerMiddleware.Key<T extends FlightServerMiddleware> - Class in org.apache.arrow.flight
A key for Flight server middleware.
FlightServiceGrpc - Class in org.apache.arrow.flight.impl
A flight service is an endpoint for retrieving or storing Arrow data.
FlightServiceGrpc.AsyncService - Interface in org.apache.arrow.flight.impl
A flight service is an endpoint for retrieving or storing Arrow data.
FlightServiceGrpc.FlightServiceBlockingStub - Class in org.apache.arrow.flight.impl
A stub to allow clients to do synchronous rpc calls to service FlightService.
FlightServiceGrpc.FlightServiceFutureStub - Class in org.apache.arrow.flight.impl
A stub to allow clients to do ListenableFuture-style rpc calls to service FlightService.
FlightServiceGrpc.FlightServiceImplBase - Class in org.apache.arrow.flight.impl
Base class for the server implementation of the service FlightService.
FlightServiceGrpc.FlightServiceStub - Class in org.apache.arrow.flight.impl
A stub to allow clients to do asynchronous rpc calls to service FlightService.
FlightServiceImplBase() - Constructor for class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceImplBase
 
FlightSql - Class in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionBeginSavepointRequest - Class in org.apache.arrow.flight.sql.impl
Request message for the "BeginSavepoint" action.
FlightSql.ActionBeginSavepointRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Request message for the "BeginSavepoint" action.
FlightSql.ActionBeginSavepointRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionBeginSavepointResult - Class in org.apache.arrow.flight.sql.impl
The result of a "BeginSavepoint" action.
FlightSql.ActionBeginSavepointResult.Builder - Class in org.apache.arrow.flight.sql.impl
The result of a "BeginSavepoint" action.
FlightSql.ActionBeginSavepointResultOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionBeginTransactionRequest - Class in org.apache.arrow.flight.sql.impl
Request message for the "BeginTransaction" action.
FlightSql.ActionBeginTransactionRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Request message for the "BeginTransaction" action.
FlightSql.ActionBeginTransactionRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionBeginTransactionResult - Class in org.apache.arrow.flight.sql.impl
The result of a "BeginTransaction" action.
FlightSql.ActionBeginTransactionResult.Builder - Class in org.apache.arrow.flight.sql.impl
The result of a "BeginTransaction" action.
FlightSql.ActionBeginTransactionResultOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionCancelQueryRequest - Class in org.apache.arrow.flight.sql.impl
Deprecated.
FlightSql.ActionCancelQueryRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Deprecated.
Request message for the "CancelQuery" action.
FlightSql.ActionCancelQueryRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
Deprecated.
FlightSql.ActionCancelQueryResult - Class in org.apache.arrow.flight.sql.impl
Deprecated.
FlightSql.ActionCancelQueryResult.Builder - Class in org.apache.arrow.flight.sql.impl
Deprecated.
The result of cancelling a query.
FlightSql.ActionCancelQueryResult.CancelResult - Enum in org.apache.arrow.flight.sql.impl
Deprecated.
Protobuf enum arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult
FlightSql.ActionCancelQueryResultOrBuilder - Interface in org.apache.arrow.flight.sql.impl
Deprecated.
FlightSql.ActionClosePreparedStatementRequest - Class in org.apache.arrow.flight.sql.impl
Request message for the "ClosePreparedStatement" action on a Flight SQL enabled backend.
FlightSql.ActionClosePreparedStatementRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Request message for the "ClosePreparedStatement" action on a Flight SQL enabled backend.
FlightSql.ActionClosePreparedStatementRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionCreatePreparedStatementRequest - Class in org.apache.arrow.flight.sql.impl
Request message for the "CreatePreparedStatement" action on a Flight SQL enabled backend.
FlightSql.ActionCreatePreparedStatementRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Request message for the "CreatePreparedStatement" action on a Flight SQL enabled backend.
FlightSql.ActionCreatePreparedStatementRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionCreatePreparedStatementResult - Class in org.apache.arrow.flight.sql.impl
Wrap the result of a "CreatePreparedStatement" or "CreatePreparedSubstraitPlan" action.
FlightSql.ActionCreatePreparedStatementResult.Builder - Class in org.apache.arrow.flight.sql.impl
Wrap the result of a "CreatePreparedStatement" or "CreatePreparedSubstraitPlan" action.
FlightSql.ActionCreatePreparedStatementResultOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionCreatePreparedSubstraitPlanRequest - Class in org.apache.arrow.flight.sql.impl
Request message for the "CreatePreparedSubstraitPlan" action on a Flight SQL enabled backend.
FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Request message for the "CreatePreparedSubstraitPlan" action on a Flight SQL enabled backend.
FlightSql.ActionCreatePreparedSubstraitPlanRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionEndSavepointRequest - Class in org.apache.arrow.flight.sql.impl
Request message for the "EndSavepoint" action.
FlightSql.ActionEndSavepointRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Request message for the "EndSavepoint" action.
FlightSql.ActionEndSavepointRequest.EndSavepoint - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.ActionEndSavepointRequest.EndSavepoint
FlightSql.ActionEndSavepointRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.ActionEndTransactionRequest - Class in org.apache.arrow.flight.sql.impl
Request message for the "EndTransaction" action.
FlightSql.ActionEndTransactionRequest.Builder - Class in org.apache.arrow.flight.sql.impl
Request message for the "EndTransaction" action.
FlightSql.ActionEndTransactionRequest.EndTransaction - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.ActionEndTransactionRequest.EndTransaction
FlightSql.ActionEndTransactionRequestOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetCatalogs - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of catalogs on a Flight SQL enabled backend.
FlightSql.CommandGetCatalogs.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of catalogs on a Flight SQL enabled backend.
FlightSql.CommandGetCatalogsOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetCrossReference - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve a description of the foreign key columns in the given foreign key table that reference the primary key or the columns representing a unique constraint of the parent table (could be the same or a different table) on a Flight SQL enabled backend.
FlightSql.CommandGetCrossReference.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve a description of the foreign key columns in the given foreign key table that reference the primary key or the columns representing a unique constraint of the parent table (could be the same or a different table) on a Flight SQL enabled backend.
FlightSql.CommandGetCrossReferenceOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetDbSchemas - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of database schemas on a Flight SQL enabled backend.
FlightSql.CommandGetDbSchemas.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of database schemas on a Flight SQL enabled backend.
FlightSql.CommandGetDbSchemasOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetExportedKeys - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve a description of the foreign key columns that reference the given table's primary key columns (the foreign keys exported by a table) of a table on a Flight SQL enabled backend.
FlightSql.CommandGetExportedKeys.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve a description of the foreign key columns that reference the given table's primary key columns (the foreign keys exported by a table) of a table on a Flight SQL enabled backend.
FlightSql.CommandGetExportedKeysOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetImportedKeys - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the foreign keys of a table on a Flight SQL enabled backend.
FlightSql.CommandGetImportedKeys.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the foreign keys of a table on a Flight SQL enabled backend.
FlightSql.CommandGetImportedKeysOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetPrimaryKeys - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the primary keys of a table on a Flight SQL enabled backend.
FlightSql.CommandGetPrimaryKeys.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the primary keys of a table on a Flight SQL enabled backend.
FlightSql.CommandGetPrimaryKeysOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetSqlInfo - Class in org.apache.arrow.flight.sql.impl
Represents a metadata request.
FlightSql.CommandGetSqlInfo.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a metadata request.
FlightSql.CommandGetSqlInfoOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetTables - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of tables, and optionally their schemas, on a Flight SQL enabled backend.
FlightSql.CommandGetTables.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of tables, and optionally their schemas, on a Flight SQL enabled backend.
FlightSql.CommandGetTablesOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetTableTypes - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of table types on a Flight SQL enabled backend.
FlightSql.CommandGetTableTypes.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve the list of table types on a Flight SQL enabled backend.
FlightSql.CommandGetTableTypesOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandGetXdbcTypeInfo - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve information about data type supported on a Flight SQL enabled backend.
FlightSql.CommandGetXdbcTypeInfo.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a request to retrieve information about data type supported on a Flight SQL enabled backend.
FlightSql.CommandGetXdbcTypeInfoOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandPreparedStatementQuery - Class in org.apache.arrow.flight.sql.impl
Represents an instance of executing a prepared statement.
FlightSql.CommandPreparedStatementQuery.Builder - Class in org.apache.arrow.flight.sql.impl
Represents an instance of executing a prepared statement.
FlightSql.CommandPreparedStatementQueryOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandPreparedStatementUpdate - Class in org.apache.arrow.flight.sql.impl
Represents a SQL update query.
FlightSql.CommandPreparedStatementUpdate.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a SQL update query.
FlightSql.CommandPreparedStatementUpdateOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandStatementQuery - Class in org.apache.arrow.flight.sql.impl
Represents a SQL query.
FlightSql.CommandStatementQuery.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a SQL query.
FlightSql.CommandStatementQueryOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandStatementSubstraitPlan - Class in org.apache.arrow.flight.sql.impl
Represents a Substrait plan.
FlightSql.CommandStatementSubstraitPlan.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a Substrait plan.
FlightSql.CommandStatementSubstraitPlanOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.CommandStatementUpdate - Class in org.apache.arrow.flight.sql.impl
Represents a SQL update query.
FlightSql.CommandStatementUpdate.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a SQL update query.
FlightSql.CommandStatementUpdateOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.DoPutUpdateResult - Class in org.apache.arrow.flight.sql.impl
Returned from the RPC call DoPut when a CommandStatementUpdate CommandPreparedStatementUpdate was in the request, containing results from the update.
FlightSql.DoPutUpdateResult.Builder - Class in org.apache.arrow.flight.sql.impl
Returned from the RPC call DoPut when a CommandStatementUpdate CommandPreparedStatementUpdate was in the request, containing results from the update.
FlightSql.DoPutUpdateResultOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.Nullable - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.Nullable
FlightSql.Searchable - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.Searchable
FlightSql.SqlInfo - Enum in org.apache.arrow.flight.sql.impl
Options for CommandGetSqlInfo.
FlightSql.SqlNullOrdering - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlNullOrdering
FlightSql.SqlOuterJoinsSupportLevel - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlOuterJoinsSupportLevel
FlightSql.SqlSupportedCaseSensitivity - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedCaseSensitivity
FlightSql.SqlSupportedElementActions - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedElementActions
FlightSql.SqlSupportedGroupBy - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedGroupBy
FlightSql.SqlSupportedPositionedCommands - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedPositionedCommands
FlightSql.SqlSupportedResultSetConcurrency - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedResultSetConcurrency
FlightSql.SqlSupportedResultSetType - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedResultSetType
FlightSql.SqlSupportedSubqueries - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedSubqueries
FlightSql.SqlSupportedTransaction - Enum in org.apache.arrow.flight.sql.impl
The level of support for Flight SQL transaction RPCs.
FlightSql.SqlSupportedTransactions - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedTransactions
FlightSql.SqlSupportedUnions - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportedUnions
FlightSql.SqlSupportsConvert - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlSupportsConvert
FlightSql.SqlTransactionIsolationLevel - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SqlTransactionIsolationLevel
FlightSql.SubstraitPlan - Class in org.apache.arrow.flight.sql.impl
An embedded message describing a Substrait plan to execute.
FlightSql.SubstraitPlan.Builder - Class in org.apache.arrow.flight.sql.impl
An embedded message describing a Substrait plan to execute.
FlightSql.SubstraitPlanOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.SupportedAnsi92SqlGrammarLevel - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SupportedAnsi92SqlGrammarLevel
FlightSql.SupportedSqlGrammar - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.SupportedSqlGrammar
FlightSql.TicketStatementQuery - Class in org.apache.arrow.flight.sql.impl
Represents a ticket resulting from GetFlightInfo with a CommandStatementQuery.
FlightSql.TicketStatementQuery.Builder - Class in org.apache.arrow.flight.sql.impl
Represents a ticket resulting from GetFlightInfo with a CommandStatementQuery.
FlightSql.TicketStatementQueryOrBuilder - Interface in org.apache.arrow.flight.sql.impl
 
FlightSql.UpdateDeleteRules - Enum in org.apache.arrow.flight.sql.impl
Protobuf enum arrow.flight.protocol.sql.UpdateDeleteRules
FlightSql.XdbcDataType - Enum in org.apache.arrow.flight.sql.impl
The JDBC/ODBC-defined type of any object.
FlightSql.XdbcDatetimeSubcode - Enum in org.apache.arrow.flight.sql.impl
Detailed subtype information for XDBC_TYPE_DATETIME and XDBC_TYPE_INTERVAL.
flightSqlClient - Variable in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
 
FlightSqlClient - Class in org.apache.arrow.flight.sql
Flight client with Flight SQL semantics.
FlightSqlClient(FlightClient) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient
 
FlightSqlClient.PreparedStatement - Class in org.apache.arrow.flight.sql
Helper class to encapsulate Flight SQL prepared statement logic.
FlightSqlClient.Savepoint - Class in org.apache.arrow.flight.sql
A handle for an active savepoint.
FlightSqlClient.SubstraitPlan - Class in org.apache.arrow.flight.sql
A wrapper around a Substrait plan and a Substrait version.
FlightSqlClient.Transaction - Class in org.apache.arrow.flight.sql
A handle for an active transaction.
FlightSqlClientDemoApp - Class in org.apache.arrow.flight.sql.example
Flight SQL Client Demo CLI Application.
FlightSqlClientDemoApp(BufferAllocator) - Constructor for class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
 
FlightSqlColumnMetadata - Class in org.apache.arrow.flight.sql
Metadata for a column in a Flight SQL query.
FlightSqlColumnMetadata(Map<String, String>) - Constructor for class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Creates a new instance of FlightSqlColumnMetadata.
FlightSqlColumnMetadata.Builder - Class in org.apache.arrow.flight.sql
Builder of FlightSqlColumnMetadata, used on FlightSqlProducer implementations.
FlightSqlExtensionScenario - Class in org.apache.arrow.flight.integration.tests
Integration test scenario for validating Flight SQL specs across multiple implementations.
FlightSqlExtensionScenario() - Constructor for class org.apache.arrow.flight.integration.tests.FlightSqlExtensionScenario
 
FlightSqlProducer - Interface in org.apache.arrow.flight.sql
API to Implement an Arrow Flight SQL producer.
FlightSqlProducer.Schemas - Class in org.apache.arrow.flight.sql
Default schema templates for the FlightSqlProducer.
FlightSqlScenario - Class in org.apache.arrow.flight.integration.tests
Integration test scenario for validating Flight SQL specs across multiple implementations.
FlightSqlScenario() - Constructor for class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
FlightSqlScenarioProducer - Class in org.apache.arrow.flight.integration.tests
Hardcoded Flight SQL producer used for cross-language integration tests.
FlightSqlScenarioProducer(BufferAllocator) - Constructor for class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
FlightSqlUtils - Class in org.apache.arrow.flight.sql
Utilities to work with Flight SQL semantics.
FlightSqlUtils() - Constructor for class org.apache.arrow.flight.sql.FlightSqlUtils
 
FlightStatusCode - Enum in org.apache.arrow.flight
A status code describing the result of a Flight call.
FlightStream - Class in org.apache.arrow.flight
An adaptor between protobuf streams and flight data streams.
FlightStream(BufferAllocator, int, FlightStream.Cancellable, FlightStream.Requestor) - Constructor for class org.apache.arrow.flight.FlightStream
Constructs a new instance.
FlightStream.Cancellable - Interface in org.apache.arrow.flight
Provides a callback to cancel a process that is in progress.
FlightStream.Requestor - Interface in org.apache.arrow.flight
Provides a interface to request more items from a stream producer.
float4(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
float4() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
float4(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
float4(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
float4(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
float4() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
float4() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
float4() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
float4() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
float4() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
float4() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
float4(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
float4(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Float4Binder - Class in org.apache.arrow.adapter.jdbc.binder
A binder for 32-bit floats.
Float4Binder(Float4Vector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Float4Binder
 
Float4Binder(Float4Vector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Float4Binder
 
Float4Comparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Float4Comparator
 
Float4EpsilonEqualizer(float) - Constructor for class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.Float4EpsilonEqualizer
 
Float4Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
Float4Holder() - Constructor for class org.apache.arrow.vector.holders.Float4Holder
 
Float4HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
Float4HolderReaderImpl(Float4Holder) - Constructor for class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
Float4Reader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
Float4ReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
Float4ReaderImpl(Float4Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
Float4Vector - Class in org.apache.arrow.vector
Float4Vector implements a fixed width vector (4 bytes) of float values which could be null.
Float4Vector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float4Vector
Instantiate a Float4Vector.
Float4Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float4Vector
Instantiate a Float4Vector.
Float4Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float4Vector
Instantiate a Float4Vector.
Float4Writer - Interface in org.apache.arrow.vector.complex.writer
 
Float4WriterImpl - Class in org.apache.arrow.vector.complex.impl
 
Float4WriterImpl(Float4Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
float8() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
float8() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
float8() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
float8() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
float8() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
float8() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
float8() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
float8(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
float8(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Float8Binder - Class in org.apache.arrow.adapter.jdbc.binder
A binder for 64-bit floats.
Float8Binder(Float8Vector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Float8Binder
 
Float8Binder(Float8Vector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Float8Binder
 
Float8Comparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.Float8Comparator
 
Float8EpsilonEqualizer(double) - Constructor for class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.Float8EpsilonEqualizer
 
Float8Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
Float8Holder() - Constructor for class org.apache.arrow.vector.holders.Float8Holder
 
Float8HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
Float8HolderReaderImpl(Float8Holder) - Constructor for class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
Float8Reader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
Float8ReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
Float8ReaderImpl(Float8Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
Float8Vector - Class in org.apache.arrow.vector
Float8Vector implements a fixed width vector (8 bytes) of double values which could be null.
Float8Vector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float8Vector
Instantiate a Float8Vector.
Float8Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float8Vector
Instantiate a Float8Vector.
Float8Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float8Vector
Instantiate a Float8Vector.
Float8Writer - Interface in org.apache.arrow.vector.complex.writer
 
Float8WriterImpl - Class in org.apache.arrow.vector.complex.impl
 
Float8WriterImpl(Float8Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
FloatConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume float type values from ResultSet.
FloatConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.FloatConsumer
 
FloatingPoint - Class in org.apache.arrow.flatbuf
 
FloatingPoint() - Constructor for class org.apache.arrow.flatbuf.FloatingPoint
 
FloatingPoint - Static variable in class org.apache.arrow.flatbuf.Type
 
FloatingPoint(FloatingPointPrecision) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
FloatingPoint.Vector - Class in org.apache.arrow.flatbuf
 
FloatingPointAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for FloatingPoint Arrow types.
FloatingPointAvaticaParameterConverter(ArrowType.FloatingPoint) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.FloatingPointAvaticaParameterConverter
 
FloatingPointEpsilonEqualizer(double) - Constructor for class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.FloatingPointEpsilonEqualizer
 
FloatingPointPrecision - Enum in org.apache.arrow.vector.types
Precisions of primitive floating point numbers.
FloatingPointVector - Interface in org.apache.arrow.vector
The interface for vectors with floating point values.
Footer - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- Arrow File metadata
Footer() - Constructor for class org.apache.arrow.flatbuf.Footer
 
Footer.Vector - Class in org.apache.arrow.flatbuf
 
forceAllocate(long) - Method in interface org.apache.arrow.memory.BufferAllocator
Forcibly allocate bytes.
ForeignAllocation - Class in org.apache.arrow.memory
EXPERIMENTAL: a memory allocation that does not come from a BufferAllocator, but rather an outside source (like JNI).
ForeignAllocation(long, long) - Constructor for class org.apache.arrow.memory.ForeignAllocation
Create a new AllocationManager representing an imported buffer.
forGrpcDomainSocket(String) - Static method in class org.apache.arrow.flight.Location
Construct a URI for a Flight+gRPC server over a Unix domain socket.
forGrpcInsecure(String, int) - Static method in class org.apache.arrow.flight.Location
Construct a URI for a Flight+gRPC server without transport security.
forGrpcTls(String, int) - Static method in class org.apache.arrow.flight.Location
Construct a URI for a Flight+gRPC server with transport security.
formatDate - Static variable in class org.apache.arrow.vector.util.DateUtility
 
formatIntervalDay(Duration) - Static method in class org.apache.arrow.driver.jdbc.utils.IntervalStringUtils
Formats a period similar to Oracle INTERVAL DAY TO SECOND data type.
.
formatIntervalYear(Period) - Static method in class org.apache.arrow.driver.jdbc.utils.IntervalStringUtils
Formats a period similar to Oracle INTERVAL YEAR TO MONTH data type
.
formatTime - Static variable in class org.apache.arrow.vector.util.DateUtility
 
formatTimeStampMilli - Static variable in class org.apache.arrow.vector.util.DateUtility
 
formatTimeStampTZ - Static variable in class org.apache.arrow.vector.util.DateUtility
 
forNumber(int) - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
 
forNumber(int) - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
 
forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
 
forVector(FieldVector) - Static method in interface org.apache.arrow.adapter.jdbc.binder.ColumnBinder
Create a column binder for a vector, using the default JDBC type code for null values.
forVector(FieldVector, Integer) - Static method in interface org.apache.arrow.adapter.jdbc.binder.ColumnBinder
Create a column binder for a vector, overriding the JDBC type code used for null values.
free() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
fromCompressionType(byte) - Static method in enum org.apache.arrow.vector.compression.CompressionUtil.CodecType
Gets the codec type from the compression type defined in CompressionType.
fromFlatbufID(short) - Static method in enum org.apache.arrow.vector.types.DateUnit
 
fromFlatbufID(short) - Static method in enum org.apache.arrow.vector.types.FloatingPointPrecision
 
fromFlatbufID(short) - Static method in enum org.apache.arrow.vector.types.IntervalUnit
 
fromFlatbufID(short) - Static method in enum org.apache.arrow.vector.types.MetadataVersion
 
fromFlatbufID(short) - Static method in enum org.apache.arrow.vector.types.TimeUnit
 
fromFlatbufID(short) - Static method in enum org.apache.arrow.vector.types.UnionMode
 
fromGrpcRuntimeException(StatusRuntimeException) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert from a gRPC exception to a Flight exception.
fromGrpcStatus(Status) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert from a gRPC status to a Flight status.
fromGrpcStatusAndTrailers(Status, Metadata) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert from a gRPC Status & trailers to a Flight status.
fromGrpcStatusCode(Status.Code) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert from a gRPC status code to a Flight status code.
fromJSON(String) - Static method in class org.apache.arrow.vector.types.pojo.Schema
 
fromProtocol(String) - Static method in enum org.apache.arrow.flight.FlightMethod
Convert a method name string into a FlightMethod.
fromThrowable(Throwable) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert arbitrary exceptions to a FlightRuntimeException.
fromVectorSchemaRoot(VectorSchemaRoot) - Static method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcVectorSchemaRootResultSet
Instantiate a ResultSet backed up by given VectorSchemaRoot.

G

GeneralOutOfPlaceVectorSorter<V extends ValueVector> - Class in org.apache.arrow.algorithm.sort
An out-of-place sorter for vectors of arbitrary type, with time complexity O(n*log(n)).
GeneralOutOfPlaceVectorSorter() - Constructor for class org.apache.arrow.algorithm.sort.GeneralOutOfPlaceVectorSorter
 
GeneratedBearerTokenAuthenticator - Class in org.apache.arrow.flight.auth2
Generates and caches bearer tokens from user credentials.
GeneratedBearerTokenAuthenticator(CallHeaderAuthenticator) - Constructor for class org.apache.arrow.flight.auth2.GeneratedBearerTokenAuthenticator
Generate bearer tokens for the given basic call authenticator.
GeneratedBearerTokenAuthenticator(CallHeaderAuthenticator, int) - Constructor for class org.apache.arrow.flight.auth2.GeneratedBearerTokenAuthenticator
Generate bearer tokens for the given basic call authenticator.
GeneratedBearerTokenAuthenticator(CallHeaderAuthenticator, CacheBuilder<Object, Object>) - Constructor for class org.apache.arrow.flight.auth2.GeneratedBearerTokenAuthenticator
Generate bearer tokens for the given basic call authenticator.
generateFlightInfo(T, FlightDescriptor, Schema) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
GenerateSampleData - Class in org.apache.arrow.vector
Helper class to generate test data for Nullable fixed and variable width scalar vectors.
generateTestData(ValueVector, int) - Static method in class org.apache.arrow.vector.GenerateSampleData
Populates vector with valueCount random values.
get(Properties) - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
Gets the property.
get(int) - Method in class org.apache.arrow.flatbuf.Binary.Vector
 
get(Binary, int) - Method in class org.apache.arrow.flatbuf.Binary.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.BinaryView.Vector
 
get(BinaryView, int) - Method in class org.apache.arrow.flatbuf.BinaryView.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Block.Vector
 
get(Block, int) - Method in class org.apache.arrow.flatbuf.Block.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.BodyCompression.Vector
 
get(BodyCompression, int) - Method in class org.apache.arrow.flatbuf.BodyCompression.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Bool.Vector
 
get(Bool, int) - Method in class org.apache.arrow.flatbuf.Bool.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Buffer.Vector
 
get(Buffer, int) - Method in class org.apache.arrow.flatbuf.Buffer.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Date.Vector
 
get(Date, int) - Method in class org.apache.arrow.flatbuf.Date.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Decimal.Vector
 
get(Decimal, int) - Method in class org.apache.arrow.flatbuf.Decimal.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.DictionaryBatch.Vector
 
get(DictionaryBatch, int) - Method in class org.apache.arrow.flatbuf.DictionaryBatch.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding.Vector
 
get(DictionaryEncoding, int) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Duration.Vector
 
get(Duration, int) - Method in class org.apache.arrow.flatbuf.Duration.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Field.Vector
 
get(Field, int) - Method in class org.apache.arrow.flatbuf.Field.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.FieldNode.Vector
 
get(FieldNode, int) - Method in class org.apache.arrow.flatbuf.FieldNode.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary.Vector
 
get(FixedSizeBinary, int) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.FixedSizeList.Vector
 
get(FixedSizeList, int) - Method in class org.apache.arrow.flatbuf.FixedSizeList.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.FloatingPoint.Vector
 
get(FloatingPoint, int) - Method in class org.apache.arrow.flatbuf.FloatingPoint.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Footer.Vector
 
get(Footer, int) - Method in class org.apache.arrow.flatbuf.Footer.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Int.Vector
 
get(Int, int) - Method in class org.apache.arrow.flatbuf.Int.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Interval.Vector
 
get(Interval, int) - Method in class org.apache.arrow.flatbuf.Interval.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.KeyValue.Vector
 
get(KeyValue, int) - Method in class org.apache.arrow.flatbuf.KeyValue.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.LargeBinary.Vector
 
get(LargeBinary, int) - Method in class org.apache.arrow.flatbuf.LargeBinary.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.LargeList.Vector
 
get(LargeList, int) - Method in class org.apache.arrow.flatbuf.LargeList.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.LargeListView.Vector
 
get(LargeListView, int) - Method in class org.apache.arrow.flatbuf.LargeListView.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.LargeUtf8.Vector
 
get(LargeUtf8, int) - Method in class org.apache.arrow.flatbuf.LargeUtf8.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.List.Vector
 
get(List, int) - Method in class org.apache.arrow.flatbuf.List.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.ListView.Vector
 
get(ListView, int) - Method in class org.apache.arrow.flatbuf.ListView.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Map.Vector
 
get(Map, int) - Method in class org.apache.arrow.flatbuf.Map.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Message.Vector
 
get(Message, int) - Method in class org.apache.arrow.flatbuf.Message.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Null.Vector
 
get(Null, int) - Method in class org.apache.arrow.flatbuf.Null.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.RecordBatch.Vector
 
get(RecordBatch, int) - Method in class org.apache.arrow.flatbuf.RecordBatch.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.RunEndEncoded.Vector
 
get(RunEndEncoded, int) - Method in class org.apache.arrow.flatbuf.RunEndEncoded.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Schema.Vector
 
get(Schema, int) - Method in class org.apache.arrow.flatbuf.Schema.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX.Vector
 
get(SparseMatrixIndexCSX, int) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.SparseTensor.Vector
 
get(SparseTensor, int) - Method in class org.apache.arrow.flatbuf.SparseTensor.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO.Vector
 
get(SparseTensorIndexCOO, int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF.Vector
 
get(SparseTensorIndexCSF, int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Struct_.Vector
 
get(Struct_, int) - Method in class org.apache.arrow.flatbuf.Struct_.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Tensor.Vector
 
get(Tensor, int) - Method in class org.apache.arrow.flatbuf.Tensor.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.TensorDim.Vector
 
get(TensorDim, int) - Method in class org.apache.arrow.flatbuf.TensorDim.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Time.Vector
 
get(Time, int) - Method in class org.apache.arrow.flatbuf.Time.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Timestamp.Vector
 
get(Timestamp, int) - Method in class org.apache.arrow.flatbuf.Timestamp.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Union.Vector
 
get(Union, int) - Method in class org.apache.arrow.flatbuf.Union.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Utf8.Vector
 
get(Utf8, int) - Method in class org.apache.arrow.flatbuf.Utf8.Vector
 
get(int) - Method in class org.apache.arrow.flatbuf.Utf8View.Vector
 
get(Utf8View, int) - Method in class org.apache.arrow.flatbuf.Utf8View.Vector
 
get(String) - Method in interface org.apache.arrow.flight.CallHeaders
Get the value of a metadata key.
get(String) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
get(String) - Method in class org.apache.arrow.flight.FlightCallHeaders
 
get(String) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
get(String) - Method in class org.apache.arrow.flight.grpc.RequestContextAdapter
 
get(String) - Method in interface org.apache.arrow.flight.RequestContext
Retrieve a registered variable.
get(K) - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Returns the value of the mapping with the specified key.
get(ArrowBuf, ArrowBuf, int) - Static method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Method used by Json Writer to read a variable width element from the variable width vector and write to Json.
get(ArrowBuf, ArrowBuf, int) - Static method in class org.apache.arrow.vector.BaseVariableWidthVector
Method used by Json Writer to read a variable width element from the variable width vector and write to Json.
get(int) - Method in class org.apache.arrow.vector.BigIntVector
Get the element at the given index from the vector.
get(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.BigIntVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.BigIntVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.BitVector
Get the element at the given index from the vector.
get(int, NullableBitHolder) - Method in class org.apache.arrow.vector.BitVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Check if a bit at a given index is set or not.
get(int, DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
get(int, ComplexHolder) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
get(int, ComplexHolder) - Method in class org.apache.arrow.vector.complex.StructVector
 
get(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
get(int, ComplexHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
get(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
get(int) - Method in class org.apache.arrow.vector.DateDayVector
Get the element at the given index from the vector.
get(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.DateDayVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.DateDayVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.DateMilliVector
Get the element at the given index from the vector.
get(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.DateMilliVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.DateMilliVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.Decimal256Vector
Get the element at the given index from the vector.
get(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.Decimal256Vector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.DecimalVector
Get the element at the given index from the vector.
get(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.DecimalVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.DurationVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.DurationVector
Get the element at the given index from the vector.
get(int, NullableDurationHolder) - Method in class org.apache.arrow.vector.DurationVector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Get the element at the given index from the vector.
get(int, NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.FixedSizeBinaryVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.Float4Vector
Get the element at the given index from the vector.
get(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.Float4Vector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.Float4Vector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.Float8Vector
Get the element at the given index from the vector.
get(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.Float8Vector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.Float8Vector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.IntervalDayVector
Get the element at the given index from the vector.
get(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.IntervalDayVector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Get the element at the given index from the vector.
get(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.IntervalYearVector
Get the element at the given index from the vector.
get(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.IntervalYearVector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.IntVector
Get the element at the given index from the vector.
get(int, NullableIntHolder) - Method in class org.apache.arrow.vector.IntVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.IntVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Get the variable length element at specified index as byte array.
get(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Get the variable length element at specified index and sets the state in provided holder.
get(int) - Method in class org.apache.arrow.vector.LargeVarCharVector
Get the variable length element at specified index as byte array.
get(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.LargeVarCharVector
Get the variable length element at specified index and sets the state in provided holder.
get(int) - Method in class org.apache.arrow.vector.SmallIntVector
Get the element at the given index from the vector.
get(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.SmallIntVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.SmallIntVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.TimeMicroVector
Get the element at the given index from the vector.
get(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.TimeMicroVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.TimeMicroVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.TimeMilliVector
Get the element at the given index from the vector.
get(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.TimeMilliVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.TimeMilliVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.TimeNanoVector
Get the element at the given index from the vector.
get(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.TimeNanoVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.TimeNanoVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.TimeSecVector
Get the element at the given index from the vector.
get(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.TimeSecVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.TimeSecVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Get the element at the given index from the vector and sets the state in holder.
get(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Get the element at the given index from the vector and sets the state in holder.
get(int, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Get the element at the given index from the vector and sets the state in holder.
get(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Get the element at the given index from the vector and sets the state in holder.
get(int, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Get the element at the given index from the vector and sets the state in holder.
get(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Get the element at the given index from the vector and sets the state in holder.
get(int, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Get the element at the given index from the vector and sets the state in holder.
get(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.TimeStampSecVector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.TimeStampVector
Get the element at the given index from the vector.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.TimeStampVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.TinyIntVector
Get the element at the given index from the vector.
get(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.TinyIntVector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.TinyIntVector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.UInt1Vector
Get the element at the given index from the vector.
get(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.UInt1Vector
Get the element at the given index from the vector and sets the state in holder.
get(ArrowBuf, int) - Static method in class org.apache.arrow.vector.UInt2Vector
Given a data buffer, get the value stored at a particular position in the vector.
get(int) - Method in class org.apache.arrow.vector.UInt2Vector
Get the element at the given index from the vector.
get(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.UInt2Vector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.UInt4Vector
Get the element at the given index from the vector.
get(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.UInt4Vector
Get the element at the given index from the vector and sets the state in holder.
get(int) - Method in class org.apache.arrow.vector.UInt8Vector
Get the element at the given index from the vector.
get(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.UInt8Vector
Get the element at the given index from the vector and sets the state in holder.
get(K) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
get(K) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
get(K) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
get set of values for key.
get(K) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
get(int) - Method in class org.apache.arrow.vector.VarBinaryVector
Get the variable length element at specified index as byte array.
get(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.VarBinaryVector
Get the variable length element at specified index and sets the state in provided holder.
get(int) - Method in class org.apache.arrow.vector.VarCharVector
Get the variable length element at specified index as byte array.
get(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.VarCharVector
Get the variable length element at specified index and sets the state in provided holder.
GET_CATALOGS_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_CROSS_REFERENCE_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_EXPORTED_KEYS_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_IMPORTED_KEYS_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_PRIMARY_KEYS_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_SCHEMAS_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_SQL_INFO_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_TABLE_TYPES_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_TABLES_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_TABLES_SCHEMA_NO_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
GET_TYPE_INFO_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
 
getAccessor() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
Returns an accessor for UnionVector child vector on current row.
getAccountant() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
 
getAccountedSize() - Method in class org.apache.arrow.memory.BufferLedger
How much memory is accounted for by this ledger.
getAccountedSize() - Method in interface org.apache.arrow.memory.ReferenceManager
Get the total accounted size (in bytes).
getAction() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Whether to rollback/release the given savepoint.
getAction() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
Whether to rollback/release the given savepoint.
getAction() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequestOrBuilder
Whether to rollback/release the given savepoint.
getAction() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Whether to commit/rollback the given transaction.
getAction() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
Whether to commit/rollback the given transaction.
getAction() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequestOrBuilder
Whether to commit/rollback the given transaction.
getActionValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Whether to rollback/release the given savepoint.
getActionValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
Whether to rollback/release the given savepoint.
getActionValue() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequestOrBuilder
Whether to rollback/release the given savepoint.
getActionValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Whether to commit/rollback the given transaction.
getActionValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
Whether to commit/rollback the given transaction.
getActionValue() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequestOrBuilder
Whether to commit/rollback the given transaction.
getActualMemoryConsumed() - Method in class org.apache.arrow.memory.ArrowBuf
Return that is Accounted for by this buffer (and its potentially shared siblings within the context of the associated allocator).
getAll(String) - Method in interface org.apache.arrow.flight.CallHeaders
Get all values present for the given metadata key.
getAll(String) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
getAll(String) - Method in class org.apache.arrow.flight.FlightCallHeaders
 
getAll(String) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
getAll(K) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
getAll(K) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
getAll(K) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
get set of values for key.
getAll(K) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
getAllByte(String) - Method in interface org.apache.arrow.flight.CallHeaders
Get all values present for the given metadata key.
getAllByte(String) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
getAllByte(String) - Method in class org.apache.arrow.flight.FlightCallHeaders
 
getAllByte(String) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
getAllocatedMemory() - Method in interface org.apache.arrow.memory.BufferAllocator
Returns the amount of memory currently allocated from this allocator.
getAllocatedSize() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
 
getAllocationFit() - Method in class org.apache.arrow.memory.BufferLedger.TransferResult
 
getAllocationFit() - Method in class org.apache.arrow.memory.OwnershipTransferNOOP
 
getAllocationFit() - Method in interface org.apache.arrow.memory.OwnershipTransferResult
 
getAllocationManager() - Method in class org.apache.arrow.memory.BufferLedger
Get the AllocationManager used by this BufferLedger.
getAllocator() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
The Arrow memory allocator.
getAllocator() - Method in class org.apache.arrow.AvroToArrowConfig
 
getAllocator() - Method in class org.apache.arrow.memory.BufferLedger
Get the buffer allocator associated with this reference manager.
getAllocator() - Method in interface org.apache.arrow.memory.ReferenceManager
Get the buffer allocator associated with this reference manager.
getAllocator() - Method in class org.apache.arrow.vector.BaseValueVector
 
getAllocator() - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
getAllocator() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getAllocator() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getAllocator() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getAllocator() - Method in class org.apache.arrow.vector.NullVector
 
getAllocator() - Method in interface org.apache.arrow.vector.ValueVector
 
getApplicationMetadata() - Method in class org.apache.arrow.flight.PutResult
Get the metadata in this message.
getAppMetadata() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFlightStreamResultSet
Expose appMetadata associated with the underlying FlightInfo for this ResultSet.
getAppMetadata() - Method in class org.apache.arrow.flight.FlightEndpoint
 
getAppMetadata() - Method in class org.apache.arrow.flight.FlightInfo
 
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
Application-defined metadata.
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
Application-defined metadata.
getAppMetadata() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDataOrBuilder
Application-defined metadata.
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Application-defined metadata.
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
Application-defined metadata.
getAppMetadata() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
Application-defined metadata.
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
Application-defined metadata.
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
Application-defined metadata.
getAppMetadata() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
Application-defined metadata.
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
bytes app_metadata = 1;
getAppMetadata() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
bytes app_metadata = 1;
getAppMetadata() - Method in interface org.apache.arrow.flight.impl.Flight.PutResultOrBuilder
bytes app_metadata = 1;
getArray() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getArray() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcListVectorAccessor
 
getArray() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getArray() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getArray(Map<String, Class<?>>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getArray(long, int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getArray(long, int, Map<String, Class<?>>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getArraySubTypeByColumnIndex(int) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Returns the array sub-type JdbcFieldInfo defined for the provided column index.
getArraySubTypeByColumnName(String) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Returns the array sub-type JdbcFieldInfo defined for the provided column name.
getArrowType() - Method in exception org.apache.arrow.adapter.jdbc.consumer.exceptions.JdbcConsumerException
 
getArrowTypeFromJdbcType(JdbcFieldInfo, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Converts the provided JDBC type to its respective ArrowType counterpart.
getAsciiStream() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getAsciiStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getAsciiStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getAsciiStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getAsStringBuilder(int) - Method in class org.apache.arrow.vector.DurationVector
Get the Interval value at a given index as a StringBuilder object.
getAsStringBuilder(int) - Method in class org.apache.arrow.vector.IntervalDayVector
Get the Interval value at a given index as a StringBuilder object.
getAsStringBuilder(int) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Get the Interval value at a given index as a StringBuilder object.
getAsStringBuilder(int) - Method in class org.apache.arrow.vector.IntervalYearVector
Get the Interval value at a given index as a StringBuilder object.
getAuthenticate(FlightClient, CredentialCallOption, CallOption...) - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Gets the CredentialCallOption for the provided authentication info.
getAuthenticate(FlightClient, String, String, ClientIncomingAuthHeaderMiddleware.Factory, CallOption...) - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Gets the CredentialCallOption for the provided authentication info.
getAuthResultWithBearerToken(CallHeaderAuthenticator.AuthResult) - Method in class org.apache.arrow.flight.auth2.BearerTokenAuthenticator
Callback to run when the initial authenticator succeeds.
getAuthResultWithBearerToken(CallHeaderAuthenticator.AuthResult) - Method in class org.apache.arrow.flight.auth2.GeneratedBearerTokenAuthenticator
 
getAutoCommit() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getBaseType() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getBaseTypeName() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getBigDecimal(int) - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getBigDecimal(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getBigDecimal(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getBigDecimal(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getBigDecimal(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getBigDecimal(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getBigDecimal() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getBigDecimal(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getBigDecimalFromArrowBuf(ArrowBuf, int, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Read an ArrowType.Decimal at the given value index in the ArrowBuf and convert to a BigDecimal with the given scale.
getBigDecimalFromByteBuffer(ByteBuffer, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Read an ArrowType.Decimal from the ByteBuffer and convert to a BigDecimal with the given scale.
getBigDecimalRoundingMode() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
 
getBigInt(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getBigInt(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getBigInt(String, NullableBigIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getBigInt(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getBigIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getBigIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getBigIntVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getBinaryStream() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getBinaryStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getBinaryStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getBit(String) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column of the given name at the current row.
getBit(int) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column with the given index at the current row.
getBit(String, NullableBitHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getBit(int, NullableBitHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getBitsFromCurrentByte(ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Returns the byte at index from data right-shifted by offset.
getBitsFromNextByte(ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Returns the byte at index from left-shifted by (8 - offset).
getBitVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getBitVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getBitVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getBitWidth() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
getBitWidth() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
getBitWidth() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
getBlob() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getBlob() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getBody() - Method in class org.apache.arrow.flight.Action
 
getBody() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
bytes body = 2;
getBody() - Method in class org.apache.arrow.flight.impl.Flight.Action
bytes body = 2;
getBody() - Method in interface org.apache.arrow.flight.impl.Flight.ActionOrBuilder
bytes body = 2;
getBody() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
bytes body = 1;
getBody() - Method in class org.apache.arrow.flight.impl.Flight.Result
bytes body = 1;
getBody() - Method in interface org.apache.arrow.flight.impl.Flight.ResultOrBuilder
bytes body = 1;
getBody() - Method in class org.apache.arrow.flight.Result
 
getBodyBuffer() - Method in class org.apache.arrow.vector.ipc.message.MessageResult
Get the message body data.
getBodyCompression() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
getBodyLength() - Method in class org.apache.arrow.vector.ipc.message.ArrowBlock
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getBoolean() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getBoolean(Properties) - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
Gets the property as Boolean.
getBuf() - Method in class org.apache.arrow.memory.util.ArrowBufPointer
Gets the underlying buffer, or null if the underlying data is invalid or null.
getBuffer() - Method in interface org.apache.arrow.memory.ReusableBuffer
Get the buffer backing this ReusableBuffer.
getBuffer() - Method in class org.apache.arrow.vector.util.ReusableByteArray
 
getBufferLayouts() - Method in class org.apache.arrow.vector.TypeLayout
Returns the individual BufferLayouts for the given type.
getBuffers(boolean) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Return the underlying buffers associated with this vector.
getBuffers(boolean) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Return the underlying buffers associated with this vector.
getBuffers(boolean) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Return the underlying buffers associated with this vector.
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.LargeListVector
Return the underlying buffers associated with this vector.
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.ListVector
Return the underlying buffers associated with this vector.
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.StructVector
Return the underlying buffers associated with this vector.
getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getBuffers(boolean) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getBuffers() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Get the record batch buffers.
getBuffers(boolean) - Method in class org.apache.arrow.vector.NullVector
 
getBuffers(boolean) - Method in interface org.apache.arrow.vector.ValueVector
Return the underlying buffers associated with this vector.
getBufferSize() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the size (number of bytes) of underlying buffers used by this vector.
getBufferSize() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the size (number of bytes) of underlying buffers used by this vector.
getBufferSize() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the size (number of bytes) of underlying buffers used by this vector.
getBufferSize() - Method in class org.apache.arrow.vector.BitVector
Get the size (number of bytes) of underlying buffers used by this vector.
getBufferSize() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
getBufferSize() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getBufferSize() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getBufferSize() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getBufferSize() - Method in class org.apache.arrow.vector.complex.LargeListVector
Get the size (number of bytes) of underlying buffers used by this vector.
getBufferSize() - Method in class org.apache.arrow.vector.complex.ListVector
Get the size (number of bytes) of underlying buffers used by this vector.
getBufferSize() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getBufferSize() - Method in class org.apache.arrow.vector.complex.StructVector
Get the size (number of bytes) of underlying buffers used by this vector.
getBufferSize() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getBufferSize() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getBufferSize() - Method in class org.apache.arrow.vector.NullVector
 
getBufferSize() - Method in interface org.apache.arrow.vector.ValueVector
Get the number of bytes used by this vector.
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the potential buffer size for a particular number of records.
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the potential buffer size for a particular number of records.
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the potential buffer size for a particular number of records.
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.BitVector
Get the potential buffer size for a particular number of records.
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.ListVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.StructVector
Get the potential buffer size for a particular number of records.
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getBufferSizeFor(int) - Method in class org.apache.arrow.vector.NullVector
 
getBufferSizeFor(int) - Method in interface org.apache.arrow.vector.ValueVector
Returns the number of bytes that is used by this vector if it holds the given number of values.
getBuffersLayout() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Get the serialized layout.
getBufferTypes() - Method in class org.apache.arrow.vector.TypeLayout
Returns the types of each buffer for this layout.
getByOrdinal(int) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
getByOrdinal(int) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
Returns the value corresponding to the given ordinal.
getByOrdinal(int) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
Returns the value corresponding to the given ordinal.
getByOrdinal(int) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
getByte(int) - Method in class io.netty.buffer.NettyArrowBuf
 
getByte(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getByte() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getByte(String) - Method in interface org.apache.arrow.flight.CallHeaders
Get the value of a metadata key.
getByte(String) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
getByte(String) - Method in class org.apache.arrow.flight.FlightCallHeaders
 
getByte(String) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
getByte(long) - Method in class org.apache.arrow.memory.ArrowBuf
Get byte value stored at a particular index in the underlying memory chunk this ArrowBuf has access to.
getByteArrayFromArrowBuf(ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Read an ArrowType.Decimal from the ArrowBuf at the given value index and return it as a byte array.
getByteBufferAddress(ByteBuffer) - Static method in class org.apache.arrow.memory.util.MemoryUtil
Given a ByteBuffer, gets the address the underlying memory space.
getByteCapacity() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the size (number of bytes) of underlying data buffer.
getByteCapacity() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the size (number of bytes) of underlying data buffer.
getByteCapacity() - Method in interface org.apache.arrow.vector.complex.RepeatedVariableWidthVectorLike
Provide the maximum amount of variable width bytes that can be stored int his vector.
getByteCapacity() - Method in interface org.apache.arrow.vector.VariableWidthVector
Provide the maximum amount of variable width bytes that can be stored in this vector.
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.NettyArrowBuf
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.NettyArrowBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.NettyArrowBuf
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.NettyArrowBuf
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getBytes() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getBytes() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getBytes() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getBytes() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getBytes() - Method in class org.apache.arrow.flight.FlightInfo
 
getBytes() - Method in class org.apache.arrow.flight.Ticket
 
getBytes(long, byte[]) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data from this ArrowBuf at a given index in into destination byte array.
getBytes(long, byte[], int, int) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data from this ArrowBuf at a given index into destination byte array.
getBytes(long, ByteBuffer) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data from this ArrowBuf at a given index into the destination ByteBuffer.
getBytes(long, ArrowBuf, long, int) - Method in class org.apache.arrow.memory.ArrowBuf
Copy a given length of data from this ArrowBuf starting at a given index into a dst ArrowBuf at dstIndex.
getBytes(long, OutputStream, int) - Method in class org.apache.arrow.memory.ArrowBuf
Copy a certain length of bytes from this ArrowBuf at a given index into the given OutputStream.
getBytes() - Method in class org.apache.arrow.vector.util.Text
Returns the raw bytes; however, only data up to ReusableByteArray.getLength() is valid.
getByteWidth() - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
 
getByteWidth() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
getCalendar() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
The calendar to use when defining Arrow Timestamp fields and retrieving Date, Time, or Timestamp data types from the ResultSet, or null if not converting.
getCallOptions() - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
Gets the current CallOption as an array; usually used as an argument in FlightSqlClient methods.
getCallToken() - Method in class org.apache.arrow.flight.auth.BasicClientAuthHandler
 
getCallToken() - Method in interface org.apache.arrow.flight.auth.ClientAuthHandler
Deprecated.
Get the per-call authentication token.
getCatalog() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies the Catalog to search for the tables.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
Specifies the Catalog to search for the tables.
getCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemasOrBuilder
Specifies the Catalog to search for the tables.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the catalog to search for the foreign key table.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the catalog to search for the foreign key table.
getCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the catalog to search for the foreign key table.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the catalog to search for the primary key table.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the catalog to search for the primary key table.
getCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the catalog to search for the primary key table.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the catalog to search for the table.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the catalog to search for the table.
getCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the catalog to search for the table.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies the Catalog to search for the tables.
getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies the Catalog to search for the tables.
getCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies the Catalog to search for the tables.
getCatalog() - Method in class org.apache.arrow.flight.sql.util.TableRef
Retrieve the catalog from the object.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies the Catalog to search for the tables.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
Specifies the Catalog to search for the tables.
getCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemasOrBuilder
Specifies the Catalog to search for the tables.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the catalog to search for the foreign key table.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the catalog to search for the foreign key table.
getCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the catalog to search for the foreign key table.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the catalog to search for the primary key table.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the catalog to search for the primary key table.
getCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the catalog to search for the primary key table.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the catalog to search for the table.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the catalog to search for the table.
getCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the catalog to search for the table.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies the Catalog to search for the tables.
getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies the Catalog to search for the tables.
getCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies the Catalog to search for the tables.
getCatalogName() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns the catalog name.
getCatalogs() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getCatalogs() - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getCatalogs" request.
getCatalogs(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a list of catalogs.
getCatalogsSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of FlightSqlClient.getCatalogs(CallOption...) from the server.
getCatalogTerm() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getCertificateInputStreamFromSystem(String) - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
It gets the trusted certificate based on the operating system and loads all the certificate into a InputStream.
getCertificateStream(String, String) - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Generates an InputStream that contains certificates for a private key.
getChar(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getChar(long) - Method in class org.apache.arrow.memory.ArrowBuf
Get char value stored at a particular index in the underlying memory chunk this ArrowBuf has access to.
getCharacterStream() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getCharacterStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getCharacterStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getCharacterStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getChild(String) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
Returns a ValueVector corresponding to the given field name if exists or null.
getChild(String, Class<T>) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
getChild(String, Class<T>) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Returns a ValueVector instance of subtype of T corresponding to the given field name if exists or null.
getChild(String, Class<T>) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getChild(String, Class<T>) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getChildAllocators() - Method in interface org.apache.arrow.memory.BufferAllocator
Returns the set of child allocators.
getChildByOrdinal(int) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Returns a ValueVector corresponding to the given ordinal identifier.
getChildFieldNames() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Get child field names.
getChildren() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Get child vectors.
getChildren() - Method in class org.apache.arrow.vector.types.pojo.Field
 
getChildrenFromFields() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the inner child vectors.
getChildrenFromFields() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the inner child vectors.
getChildrenFromFields() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the inner child vectors.
getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.ListVector
 
getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getChildrenFromFields() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getChildrenFromFields() - Method in interface org.apache.arrow.vector.FieldVector
The returned list is the same size as the list passed to initializeChildrenFromFields.
getChildrenFromFields() - Method in class org.apache.arrow.vector.NullVector
 
getChildVectorWithOrdinal(String) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
getChildVectorWithOrdinal(String) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Get a child vector by name.
getChildVectorWithOrdinal(String) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getChildVectorWithOrdinal(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getChunkSize() - Method in class io.netty.buffer.PooledByteBufAllocatorL
 
getClientCertificatePath() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
 
getClientCertificateStream(String) - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Generates an InputStream that contains certificates for a path-based mTLS Client Certificate.
getClientInfo() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightConnection
 
getClientInfo(String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getClientInfo() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getClientKeyPath() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
 
getClientKeyStream(String) - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Generates an InputStream that contains certificates for a path-based mTLS Client Key.
getClob() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getClob() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getCmd() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
Opaque value used to express a command.
getCmd() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
Opaque value used to express a command.
getCmd() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDescriptorOrBuilder
Opaque value used to express a command.
getCodec() - Method in class org.apache.arrow.vector.ipc.message.ArrowBodyCompression
 
getCodecType() - Method in class org.apache.arrow.compression.Lz4CompressionCodec
 
getCodecType() - Method in class org.apache.arrow.compression.ZstdCompressionCodec
 
getCodecType() - Method in interface org.apache.arrow.vector.compression.CompressionCodec
Gets the type of the codec.
getCodecType() - Method in class org.apache.arrow.vector.compression.NoCompressionCodec
 
getColumn() - Method in class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
The column index for query column.
getColumnMetadataByColumnIndex() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Return metadata from columnIndex->meta map on per field basis or null if not provided.
getColumns(String, String, String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getCommand() - Method in class org.apache.arrow.flight.FlightDescriptor
 
getConfig() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
getConflictPolicy() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
getConnection() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getConnection() - Method in interface org.apache.arrow.driver.jdbc.ArrowFlightInfoStatement
 
getConnection() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
getConnection(String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
getConnection() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcPooledConnection
 
getConnection() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightPreparedStatement
 
getConnection() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightStatement
 
getConnectStringPrefix() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDriver
 
getConsumer(ArrowType, int, boolean, FieldVector, JdbcToArrowConfig) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Default function used for JdbcConsumerFactory.
getConsumers() - Method in class org.apache.arrow.consumers.CompositeAvroConsumer
 
getCredentialCallOption() - Method in class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware.Factory
 
getCredentialCallOptionFromIncomingHeaders(CallHeaders) - Method in class org.apache.arrow.flight.auth2.ClientBearerHeaderHandler
 
getCredentialCallOptionFromIncomingHeaders(CallHeaders) - Method in interface org.apache.arrow.flight.auth2.ClientHeaderHandler
Parses the incoming headers and converts them into a CredentialCallOption.
getCrossReference(String, String, String, String, String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getCrossReference(String, String, String, String, String, String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getCrossReference" request based on the provided info.
getCrossReference(TableRef, TableRef, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Retrieves a description of the foreign key columns that reference the given table's primary key columns (the foreign keys exported by a table).
getCrossReferenceSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
getCurrentPosition() - Method in class org.apache.arrow.vector.ipc.WriteChannel
 
getCurrentRow() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getCurrentTypeId() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getCurrentTypeId() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcDenseUnionVectorAccessor
 
getCurrentTypeId() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcUnionVectorAccessor
 
getCustomMetadata() - Method in class org.apache.arrow.vector.types.pojo.Schema
 
getDatabaseProductName() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getDatabaseProductVersion() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getDataBody() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The actual batch of Arrow data.
getDataBody() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
The actual batch of Arrow data.
getDataBody() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDataOrBuilder
The actual batch of Arrow data.
getDataBuffer() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the buffer that stores the data for elements in the vector.
getDataBuffer() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the buffer that stores the data for elements in the vector.
getDataBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the buffer that stores the data for elements in the vector.
getDataBuffer() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.complex.ListVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.complex.StructVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getDataBuffer() - Method in class org.apache.arrow.vector.NullVector
 
getDataBuffer() - Method in interface org.apache.arrow.vector.ValueVector
Gets the underlying buffer associated with data vector.
getDataBufferAddress() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the memory address of buffer that stores the data for elements in the vector.
getDataBufferAddress() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the memory address of buffer that stores the data for elements in the vector.
getDataBufferAddress() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the memory address of buffer that stores the data for elements in the vector.
getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.ListVector
 
getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.StructVector
 
getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDataBufferAddress() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getDataBufferAddress() - Method in interface org.apache.arrow.vector.FieldVector
Gets the starting address of the underlying buffer associated with data vector.
getDataBufferAddress() - Method in class org.apache.arrow.vector.NullVector
 
getDataHeader() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
Header for message data as described in Message.fbs::Message.
getDataHeader() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
Header for message data as described in Message.fbs::Message.
getDataHeader() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDataOrBuilder
Header for message data as described in Message.fbs::Message.
getDataPointer(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
getDataPointer(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
getDataPointer(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
getDataPointer(int) - Method in class org.apache.arrow.vector.BitVector
 
getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BitVector
 
getDataPointer(int) - Method in interface org.apache.arrow.vector.ElementAddressableVector
Gets the pointer for the data at the given index.
getDataPointer(int, ArrowBufPointer) - Method in interface org.apache.arrow.vector.ElementAddressableVector
Gets the pointer for the data at the given index.
getDataSetSchema() - Method in interface org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.PreparedStatement
getDatasetSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
If a result set generating query was provided, dataset_schema contains the schema of the result set.
getDatasetSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
If a result set generating query was provided, dataset_schema contains the schema of the result set.
getDatasetSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResultOrBuilder
If a result set generating query was provided, dataset_schema contains the schema of the result set.
getDataType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
Specifies the data type to search for the info.
getDataType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
Specifies the data type to search for the info.
getDataType() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfoOrBuilder
Specifies the data type to search for the info.
getDataVector() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcListVectorAccessor
 
getDataVector() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcFixedSizeListVectorAccessor
 
getDataVector() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcLargeListVectorAccessor
 
getDataVector() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcListVectorAccessor
 
getDataVector() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcMapVectorAccessor
 
getDataVector() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getDataVector() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getDataVector() - Method in class org.apache.arrow.vector.complex.LargeListVector
Get the inner data vector for this list vector.
getDataVector() - Method in class org.apache.arrow.vector.complex.ListVector
Get the inner data vector for this list vector.
getDataVector() - Method in interface org.apache.arrow.vector.complex.RepeatedValueVector
Get the data vector.
getDate(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getDate(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
 
getDate(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getDate(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getDate(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getDateDay(String) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column of the given name at the current row.
getDateDay(int) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column with the given index at the current row.
getDateDay(String, NullableDateDayHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getDateDay(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getDateDayVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getDateDayVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDateDayVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDateMilli(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getDateMilli(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getDateMilli(String, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getDateMilli(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getDateMilliVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getDateMilliVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDateMilliVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDateTimeFormatter() - Static method in class org.apache.arrow.vector.util.DateUtility
Returns the date time formatter used to parse date strings.
getDays(ArrowBuf, int) - Static method in class org.apache.arrow.vector.IntervalDayVector
Given a data buffer, get the number of days stored at a particular position in the vector.
getDays(ArrowBuf, int) - Static method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Given a data buffer, get the number of days stored at a particular position in the vector.
getDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the schema to search for the foreign key table.
getDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the schema to search for the foreign key table.
getDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the schema to search for the foreign key table.
getDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the schema to search for the primary key table.
getDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the schema to search for the primary key table.
getDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the schema to search for the primary key table.
getDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the schema to search for the table.
getDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the schema to search for the table.
getDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the schema to search for the table.
getDbSchema() - Method in class org.apache.arrow.flight.sql.util.TableRef
Retrieves the db schema from the object.
getDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the schema to search for the foreign key table.
getDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the schema to search for the foreign key table.
getDbSchemaBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the schema to search for the foreign key table.
getDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the schema to search for the primary key table.
getDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the schema to search for the primary key table.
getDbSchemaBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the schema to search for the primary key table.
getDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the schema to search for the table.
getDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the schema to search for the table.
getDbSchemaBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the schema to search for the table.
getDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPattern() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemasOrBuilder
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPattern() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPatternBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPatternBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPatternBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemasOrBuilder
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPatternBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPatternBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter pattern for schemas to search for.
getDbSchemaFilterPatternBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter pattern for schemas to search for.
getDecimal(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the value of the holder with data from vector at the given index at the current row.
getDecimal(String, NullableDecimalHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the value of the holder with data from the vector with given name at the current row.
getDecimal(String) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column of the given name at the current row.
getDecimal(int) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column with the given index at the current row.
getDecimal256Vector(byte, ArrowType) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getDecimal256Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDecimal256Vector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDecimal256Vector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDecimalObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a BigDecimal from the column of the given name at the current row.
getDecimalObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a BigDecimal from the column with the given index at the current row.
getDecimalVector(byte, ArrowType) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getDecimalVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDecimalVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDecimalVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDefaultCharacterSet() - Method in class org.apache.arrow.vector.table.Row
Returns the default character set for use with character vectors.
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
getDefaultTransactionIsolation() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getDefinition() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
getDefinition() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
definition of entire flight.
getDefinition() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.TokenOrBuilder
definition of entire flight.
getDefinitionBuilder() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
getDefinitionOrBuilder() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
getDefinitionOrBuilder() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
definition of entire flight.
getDefinitionOrBuilder() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.TokenOrBuilder
definition of entire flight.
getDenseUnion(String) - Method in class org.apache.arrow.vector.table.Row
Returns an Object from the column of the given name at the current row.
getDenseUnion(int) - Method in class org.apache.arrow.vector.table.Row
Returns an Object from the column with the given vectorIndex at the current row.
getDensity() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the density of this ListVector.
getDensity() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the density of this ListVector.
getDensity() - Method in class org.apache.arrow.vector.complex.LargeListVector
Get the density of this ListVector.
getDensity() - Method in class org.apache.arrow.vector.complex.ListVector
Get the density of this ListVector.
getDescription() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string description = 2;
getDescription() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
string description = 2;
getDescription() - Method in interface org.apache.arrow.flight.impl.Flight.ActionTypeOrBuilder
string description = 2;
getDescriptionBytes() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string description = 2;
getDescriptionBytes() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
string description = 2;
getDescriptionBytes() - Method in interface org.apache.arrow.flight.impl.Flight.ActionTypeOrBuilder
string description = 2;
getDescriptor() - Method in class org.apache.arrow.flight.FlightInfo
 
getDescriptor() - Method in class org.apache.arrow.flight.FlightStream
Get the descriptor for this stream.
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
getDescriptor() - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
getDescriptor() - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
getDescriptor() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass
 
getDescriptor() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
getDescriptor() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
 
getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
 
getDescriptor() - Static method in class org.apache.arrow.flight.Test
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
 
getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
 
getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
 
getDetails() - Method in class org.apache.arrow.memory.AllocationOutcome
Get additional details of the allocation (like the status at each allocator in the hierarchy).
getDictionaries() - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
getDictionary() - Method in interface org.apache.arrow.algorithm.dictionary.DictionaryBuilder
Gets the dictionary built.
getDictionary() - Method in class org.apache.arrow.algorithm.dictionary.HashTableBasedDictionaryBuilder
Gets the dictionary built.
getDictionary() - Method in class org.apache.arrow.algorithm.dictionary.SearchTreeBasedDictionaryBuilder
Gets the dictionary built.
getDictionary() - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
getDictionary() - Method in class org.apache.arrow.vector.types.pojo.Field
 
getDictionary() - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
getDictionaryBlocks() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
 
getDictionaryBlocks() - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
 
getDictionaryId() - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
getDictionaryIds() - Method in interface org.apache.arrow.vector.dictionary.DictionaryProvider
Get all dictionary IDs.
getDictionaryIds() - Method in class org.apache.arrow.vector.dictionary.DictionaryProvider.MapDictionaryProvider
 
getDictionaryIds() - Method in class org.apache.arrow.vector.ipc.ArrowReader
 
getDictionaryIds() - Method in class org.apache.arrow.vector.ipc.JsonFileReader
 
getDictionaryProvider() - Method in class org.apache.arrow.flight.FlightStream
Get the provider for dictionaries in this stream.
getDictionaryProvider() - Method in class org.apache.arrow.vector.table.BaseTable
Returns the DictionaryProvider for this table.
getDictionaryVectors() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Returns any dictionaries that were loaded along with ArrowRecordBatches.
getDisableCertificateVerification() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
 
getDisplaySize() - Method in class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
The max number of characters for the column.
getDoActionMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getDoExchangeMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getDoGetMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getDoPutMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getDouble(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getDouble() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getDouble(long) - Method in class org.apache.arrow.memory.ArrowBuf
Get double value stored at a particular index in the underlying memory chunk this ArrowBuf has access to.
getDuration() - Method in class org.apache.arrow.vector.PeriodDuration
 
getDuration(String) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column of the given name at the current row.
getDuration(int) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column with the given index at the current row.
getDuration(String, NullableDurationHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getDuration(int, NullableDurationHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getDurationObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a Duration from the column of the given name at the current row.
getDurationObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a Duration from the column with the given index at the current row.
getDurationVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDurationVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getDurationVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getElementEndIndex(int) - Method in interface org.apache.arrow.vector.complex.BaseListVector
Get data vector end index with the given list index.
getElementEndIndex(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getElementEndIndex(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getElementEndIndex(int) - Method in class org.apache.arrow.vector.complex.ListVector
 
getElementStartIndex(int) - Method in interface org.apache.arrow.vector.complex.BaseListVector
Get data vector start index with the given list index.
getElementStartIndex(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getElementStartIndex(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getElementStartIndex(int) - Method in class org.apache.arrow.vector.complex.ListVector
 
getEmpty() - Method in interface org.apache.arrow.memory.BufferAllocator
Get a reference to the empty buffer associated with this allocator.
getEncoding() - Method in class org.apache.arrow.vector.dictionary.Dictionary
 
getEnd() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
exclusive end
getEnd() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
exclusive end
getEnd() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.TokenOrBuilder
exclusive end
getEndOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcListVectorAccessor
 
getEndOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcFixedSizeListVectorAccessor
 
getEndOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcLargeListVectorAccessor
 
getEndOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcListVectorAccessor
 
getEndOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcMapVectorAccessor
 
getEndOffset(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
getEndOffset(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Gets the ending offset of a record, given its index.
getEndpoint(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
getEndpoint(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
A list of endpoints associated with the flight.
getEndpoint(int) - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
A list of endpoints associated with the flight.
getEndpoint() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
getEndpoint() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
getEndpoint() - Method in interface org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequestOrBuilder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
getEndpointBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
getEndpointBuilder() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
getEndpointBuilderList() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
getEndpointCount() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
getEndpointCount() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
A list of endpoints associated with the flight.
getEndpointCount() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
A list of endpoints associated with the flight.
getEndpointList() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
getEndpointList() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
A list of endpoints associated with the flight.
getEndpointList() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
A list of endpoints associated with the flight.
getEndpointOrBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
getEndpointOrBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
A list of endpoints associated with the flight.
getEndpointOrBuilder(int) - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
A list of endpoints associated with the flight.
getEndpointOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
getEndpointOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
getEndpointOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequestOrBuilder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
getEndpointOrBuilderList() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
getEndpointOrBuilderList() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
A list of endpoints associated with the flight.
getEndpointOrBuilderList() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
A list of endpoints associated with the flight.
getEndpoints() - Method in class org.apache.arrow.flight.FlightInfo
 
getExecuteSchema(String, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of the result set of a query.
getExecuteSchema(String, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of the result set of a query.
getExecuteSubstraitSchema(FlightSqlClient.SubstraitPlan, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of the result set of a Substrait plan.
getExecuteSubstraitSchema(FlightSqlClient.SubstraitPlan, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of the result set of a Substrait plan.
getExpirationTime() - Method in class org.apache.arrow.flight.FlightEndpoint
 
getExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
getExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
Expiration time of this stream.
getExpirationTime() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
Expiration time of this stream.
getExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
getExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
Expiration time for this request.
getExpirationTime() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
Expiration time for this request.
getExpirationTime() - Method in class org.apache.arrow.flight.PollInfo
The expiration time of the query execution.
getExpirationTimeBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
getExpirationTimeBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
getExpirationTimeOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
getExpirationTimeOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
Expiration time of this stream.
getExpirationTimeOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
Expiration time of this stream.
getExpirationTimeOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
getExpirationTimeOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
Expiration time for this request.
getExpirationTimeOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
Expiration time for this request.
getExplicitTypeByColumnIndex(int) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Returns the type JdbcFieldInfo explicitly defined for the provided column index.
getExplicitTypeByColumnName(String) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Returns the type JdbcFieldInfo explicitly defined for the provided column name.
getExportedKeys(String, String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getExportedKeys(String, String, String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getExportedKeys" request based on the provided info.
getExportedKeys(TableRef, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Retrieves a description about the foreign key columns that reference the primary key columns of the given table.
getExportedKeysSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
getExpression() - Method in class org.apache.arrow.flight.Criteria
Get the contained filter criteria.
getExpression() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
bytes expression = 1;
getExpression() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
bytes expression = 1;
getExpression() - Method in interface org.apache.arrow.flight.impl.Flight.CriteriaOrBuilder
bytes expression = 1;
getExtensionType(int) - Method in class org.apache.arrow.vector.table.Row
Returns an object representing the value in the ExtensionTypeVector at the currentRow and vectorIndex.
getExtensionType(String) - Method in class org.apache.arrow.vector.table.Row
Returns an object representing the value in the named ExtensionTypeVector at the currentRow.
getExtraNameCharacters() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getFactoryClassName(UnregisteredDriver.JdbcVersion) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDriver
 
getFailedAllocator() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails
Get the allocator that caused the failure.
getField() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get information about how this field is materialized.
getField() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get information about how this field is materialized.
getField() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get information about how this field is materialized.
getField() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getField() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getField() - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
getField() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
getField() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
getField() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
getField() - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
getField() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getField() - Method in class org.apache.arrow.vector.complex.ListVector
 
getField() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getField() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
getField() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getField() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
getField() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getField() - Method in class org.apache.arrow.vector.NullVector
 
getField(String) - Method in class org.apache.arrow.vector.table.BaseTable
Returns the Field with the given name if one exists in this table.
getField(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.Field
Puts this object into builder and returns the length of the serialized flatbuffer.
getField() - Method in interface org.apache.arrow.vector.ValueVector
Get information about how this field is materialized.
getFieldBuffers() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the buffers belonging to this vector.
getFieldBuffers() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the buffers belonging to this vector.
getFieldBuffers() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the buffers belonging to this vector.
getFieldBuffers() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getFieldBuffers() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getFieldBuffers() - Method in class org.apache.arrow.vector.complex.LargeListVector
Get the buffers belonging to this vector.
getFieldBuffers() - Method in class org.apache.arrow.vector.complex.ListVector
Get the buffers belonging to this vector.
getFieldBuffers() - Method in class org.apache.arrow.vector.complex.StructVector
 
getFieldBuffers() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getFieldBuffers() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getFieldBuffers() - Method in interface org.apache.arrow.vector.FieldVector
Get the buffers of the fields, (same size as getFieldVectors() since it is their content).
getFieldBuffers() - Method in class org.apache.arrow.vector.NullVector
 
getFieldInfo() - Method in exception org.apache.arrow.adapter.jdbc.consumer.exceptions.JdbcConsumerException
 
getFieldInnerVectors() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Deprecated.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.complex.LargeListVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.complex.ListVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.complex.StructVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.complex.UnionVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.ExtensionTypeVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in interface org.apache.arrow.vector.FieldVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFieldInnerVectors() - Method in class org.apache.arrow.vector.NullVector
Deprecated.
This API will be removed as the current implementations no longer support inner vectors.
getFields() - Method in class org.apache.arrow.vector.types.pojo.Schema
 
getFieldType() - Method in class org.apache.arrow.vector.types.pojo.Field
 
getFieldVectors() - Method in class org.apache.arrow.vector.VectorSchemaRoot
 
getFirstMatch(V, VectorValueComparator<V>, V, int) - Static method in class org.apache.arrow.algorithm.search.VectorRangeSearcher
Search for the first occurrence of an element.
getFixedSizeBinary(String) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column of the given name at the current row.
getFixedSizeBinary(int) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column with the given index at the current row.
getFixedSizeBinaryVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getFixedSizeBinaryVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getFixedSizeBinaryVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getFkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the foreign table is.
getFkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The catalog name where the foreign table is.
getFkCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The catalog name where the foreign table is.
getFkCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the foreign table is.
getFkCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The catalog name where the foreign table is.
getFkCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The catalog name where the foreign table is.
getFkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The schema name where the foreign table is.
getFkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The schema name where the foreign table is.
getFkDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The schema name where the foreign table is.
getFkDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The schema name where the foreign table is.
getFkDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The schema name where the foreign table is.
getFkDbSchemaBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The schema name where the foreign table is.
getFkTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The foreign table name.
getFkTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The foreign table name.
getFkTable() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The foreign table name.
getFkTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The foreign table name.
getFkTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The foreign table name.
getFkTableBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The foreign table name.
getFlatbufID() - Method in enum org.apache.arrow.vector.types.DateUnit
 
getFlatbufID() - Method in enum org.apache.arrow.vector.types.FloatingPointPrecision
 
getFlatbufID() - Method in enum org.apache.arrow.vector.types.IntervalUnit
 
getFlatbufID() - Method in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
 
getFlatbufID() - Method in enum org.apache.arrow.vector.types.TimeUnit
 
getFlatbufID() - Method in enum org.apache.arrow.vector.types.UnionMode
 
getFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
getFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
The descriptor of the data.
getFlightDescriptor() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDataOrBuilder
The descriptor of the data.
getFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
getFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
The descriptor associated with this info.
getFlightDescriptor() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
The descriptor associated with this info.
getFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
getFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
The descriptor the client should use on the next try.
getFlightDescriptor() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
The descriptor the client should use on the next try.
getFlightDescriptor() - Method in class org.apache.arrow.flight.PollInfo
The FlightDescriptor that should be used to get further updates on this query.
getFlightDescriptorBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
getFlightDescriptorBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
getFlightDescriptorBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
getFlightDescriptorOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
getFlightDescriptorOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
The descriptor of the data.
getFlightDescriptorOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDataOrBuilder
The descriptor of the data.
getFlightDescriptorOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
getFlightDescriptorOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
The descriptor associated with this info.
getFlightDescriptorOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
The descriptor associated with this info.
getFlightDescriptorOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
getFlightDescriptorOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
The descriptor the client should use on the next try.
getFlightDescriptorOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
The descriptor the client should use on the next try.
getFlightEndpoint() - Method in class org.apache.arrow.flight.RenewFlightEndpointRequest
 
getFlightInfo(FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.FlightProducer
Get information about a particular data stream.
getFlightInfo(Flight.FlightDescriptor, StreamObserver<Flight.FlightInfo>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
For a given FlightDescriptor, get information about how the flight can be consumed.
getFlightInfo(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
For a given FlightDescriptor, get information about how the flight can be consumed.
getFlightInfo(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceFutureStub
For a given FlightDescriptor, get information about how the flight can be consumed.
getFlightInfo(Flight.FlightDescriptor, StreamObserver<Flight.FlightInfo>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
For a given FlightDescriptor, get information about how the flight can be consumed.
getFlightInfo(FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.IntegrationProducer
 
getFlightInfo(FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.NoOpFlightProducer
 
getFlightInfo() - Method in class org.apache.arrow.flight.PollInfo
The FlightInfo describing the result set of the execution of a query.
getFlightInfo(FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Depending on the provided command, method either: 1.
getFlightInfoCatalogs(FlightSql.CommandGetCatalogs, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoCatalogs(FlightSql.CommandGetCatalogs, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoCatalogs(FlightSql.CommandGetCatalogs, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns the available catalogs by returning a stream of FlightSql.CommandGetCatalogs objects in Result objects.
getFlightInfoCatalogs(FlightSql.CommandGetCatalogs, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoCrossReference(FlightSql.CommandGetCrossReference, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoCrossReference(FlightSql.CommandGetCrossReference, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoCrossReference(FlightSql.CommandGetCrossReference, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Retrieve a description of the foreign key columns that reference the given table's primary key columns FlightSql.CommandGetCrossReference objects in Result objects.
getFlightInfoCrossReference(FlightSql.CommandGetCrossReference, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoExportedKeys(FlightSql.CommandGetExportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoExportedKeys(FlightSql.CommandGetExportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoExportedKeys(FlightSql.CommandGetExportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Retrieves a description of the foreign key columns that reference the given table's primary key columns FlightSql.CommandGetExportedKeys objects in Result objects.
getFlightInfoExportedKeys(FlightSql.CommandGetExportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Retrieves a description of the primary key columns that are referenced by given table's foreign key columns FlightSql.CommandGetImportedKeys objects in Result objects.
getFlightInfoImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Gets information about a particular prepared statement data stream.
getFlightInfoPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoPrimaryKeys(FlightSql.CommandGetPrimaryKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoPrimaryKeys(FlightSql.CommandGetPrimaryKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoPrimaryKeys(FlightSql.CommandGetPrimaryKeys, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns the available primary keys by returning a stream of FlightSql.CommandGetPrimaryKeys objects in Result objects.
getFlightInfoPrimaryKeys(FlightSql.CommandGetPrimaryKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoSchemas(FlightSql.CommandGetDbSchemas, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoSchemas(FlightSql.CommandGetDbSchemas, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoSchemas(FlightSql.CommandGetDbSchemas, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns the available schemas by returning a stream of FlightSql.CommandGetDbSchemas objects in Result objects.
getFlightInfoSchemas(FlightSql.CommandGetDbSchemas, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns the SQL Info of the server by returning a FlightSql.CommandGetSqlInfo in a Result.
getFlightInfoSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoStatement(FlightSql.CommandStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoStatement(FlightSql.CommandStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Evaluate a SQL query.
getFlightInfoStatement(FlightSql.CommandStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoSubstraitPlan(FlightSql.CommandStatementSubstraitPlan, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoSubstraitPlan(FlightSql.CommandStatementSubstraitPlan, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Evaluate a Substrait plan.
getFlightInfoTables(FlightSql.CommandGetTables, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoTables(FlightSql.CommandGetTables, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoTables(FlightSql.CommandGetTables, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns the available tables by returning a stream of FlightSql.CommandGetTables objects in Result objects.
getFlightInfoTables(FlightSql.CommandGetTables, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoTableTypes(FlightSql.CommandGetTableTypes, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoTableTypes(FlightSql.CommandGetTableTypes, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoTableTypes(FlightSql.CommandGetTableTypes, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns the available table types by returning a stream of FlightSql.CommandGetTableTypes objects in Result objects.
getFlightInfoTableTypes(FlightSql.CommandGetTableTypes, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFlightInfoTypeInfo(FlightSql.CommandGetXdbcTypeInfo, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getFlightInfoTypeInfo(FlightSql.CommandGetXdbcTypeInfo, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.BasicFlightSqlProducer
 
getFlightInfoTypeInfo(FlightSql.CommandGetXdbcTypeInfo, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns a description of all the data types supported by source.
getFlightInfoTypeInfo(FlightSql.CommandGetXdbcTypeInfo, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getFloat(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getFloat() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getFloat(long) - Method in class org.apache.arrow.memory.ArrowBuf
Get float value stored at a particular index in the underlying memory chunk this ArrowBuf has access to.
getFloat4(String) - Method in class org.apache.arrow.vector.table.Row
Returns a float from the column of the given name at the current row.
getFloat4(int) - Method in class org.apache.arrow.vector.table.Row
Returns a float from the column with the given index at the current row.
getFloat4(String, NullableFloat4Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getFloat4(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getFloat4Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getFloat4Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getFloat4Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getFloat8(String) - Method in class org.apache.arrow.vector.table.Row
Returns a double from the column of the given name at the current row.
getFloat8(int) - Method in class org.apache.arrow.vector.table.Row
Returns a double from the column with the given index at the current row.
getFloat8(String, NullableFloat8Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getFloat8(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getFloat8Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getFloat8Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getFloat8Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getGetFlightInfoMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getGetSchemaMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getHandshakeMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getHeaderAttributes() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets which properties should be added as headers.
getHeadroom() - Method in interface org.apache.arrow.memory.BufferAllocator
Returns the amount of memory that can probably be allocated at this moment without exceeding this or any parents allocation maximum.
getHoldability() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getHolderForUtf8(String, ArrowBuf) - Static method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Gets a NullableVarCharHolder from the provided string using the provided buf.
getHost() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the host.
getHugeBufferCount() - Method in class io.netty.buffer.PooledByteBufAllocatorL
 
getHugeBufferSize() - Method in class io.netty.buffer.PooledByteBufAllocatorL
 
getId() - Method in class org.apache.arrow.memory.ArrowBuf
Get the integer id assigned to this ArrowBuf for debugging purposes.
getId() - Method in class org.apache.arrow.vector.types.pojo.DictionaryEncoding
 
getIdentifierQuoteString() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getImportedKeys(String, String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getImportedKeys(String, String, String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getImportedKeys" request based on the provided info.
getImportedKeys(TableRef, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Retrieves the foreign key columns for the given table.
getImportedKeysSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
getIncludeSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies if the Arrow schema should be returned for found tables.
getIncludeSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies if the Arrow schema should be returned for found tables.
getIncludeSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies if the Arrow schema should be returned for found tables.
getIndex(int, ValueVector) - Method in class org.apache.arrow.vector.dictionary.DictionaryHashTable
get the corresponding dictionary index with the given index in vector which to encode.
getIndexType(int) - Static method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
Get the indexType according to the dictionary vector valueCount.
getIndexType() - Method in class org.apache.arrow.vector.types.pojo.DictionaryEncoding
 
getInfo(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getInfo" request based on the provided query object.
getInfo() - Method in class org.apache.arrow.flight.CancelFlightInfoRequest
 
getInfo(FlightDescriptor, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Get info on a stream.
getInfo() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
getInfo() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
.arrow.flight.protocol.FlightInfo info = 1;
getInfo() - Method in interface org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequestOrBuilder
.arrow.flight.protocol.FlightInfo info = 1;
getInfo() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
getInfo() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
The currently available results.
getInfo() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
The currently available results.
getInfo() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
The result of the GetFlightInfo RPC that initiated the query.
getInfo() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
The result of the GetFlightInfo RPC that initiated the query.
getInfo() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequestOrBuilder
Deprecated.
The result of the GetFlightInfo RPC that initiated the query.
getInfo(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
Values are modelled after ODBC's SQLGetInfo() function.
getInfo(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
Values are modelled after ODBC's SQLGetInfo() function.
getInfo(int) - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfoOrBuilder
Values are modelled after ODBC's SQLGetInfo() function.
getInfoBuilder() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
getInfoBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
getInfoCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
Values are modelled after ODBC's SQLGetInfo() function.
getInfoCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
Values are modelled after ODBC's SQLGetInfo() function.
getInfoCount() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfoOrBuilder
Values are modelled after ODBC's SQLGetInfo() function.
getInfoList() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
Values are modelled after ODBC's SQLGetInfo() function.
getInfoList() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
Values are modelled after ODBC's SQLGetInfo() function.
getInfoList() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfoOrBuilder
Values are modelled after ODBC's SQLGetInfo() function.
getInfoOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
getInfoOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
.arrow.flight.protocol.FlightInfo info = 1;
getInfoOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequestOrBuilder
.arrow.flight.protocol.FlightInfo info = 1;
getInfoOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
getInfoOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
The currently available results.
getInfoOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
The currently available results.
getInitReservation() - Method in interface org.apache.arrow.memory.BufferAllocator
Return the initial reservation.
getInnerValueCount() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getInnerValueCountAt(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Returns the value count for inner data vector at a particular index.
getInstance() - Static method in class org.apache.arrow.flight.NoOpStreamListener
 
getInt(int) - Method in class io.netty.buffer.NettyArrowBuf
 
getInt(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getInt() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getInt(long) - Method in class org.apache.arrow.memory.ArrowBuf
Get int value stored at a particular index in the underlying memory chunk this ArrowBuf has access to.
getInt(String) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column of the given name at the current row.
getInt(int) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column with the given index at the current row.
getInt(String, NullableIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getInt(int, NullableIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getInt(Field) - Static method in class org.apache.arrow.vector.types.pojo.ArrowType
 
getInteger(Properties) - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
Gets the property as Integer.
getIntervalDay(String) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column of the given name at the current row.
getIntervalDay(int) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column with the given index at the current row.
getIntervalDay(String, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getIntervalDay(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getIntervalDayObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a Duration from the column with the given index at the current row.
getIntervalDayObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a Duration from the column of the given name at the current row.
getIntervalDayVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getIntervalDayVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIntervalDayVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIntervalMonthDayNano(String) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column of the given name at the current row.
getIntervalMonthDayNano(int) - Method in class org.apache.arrow.vector.table.Row
Returns an ArrowBuf from the column with the given index at the current row.
getIntervalMonthDayNano(String, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getIntervalMonthDayNano(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getIntervalMonthDayNanoObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a PeriodDuration from the column of the given name at the current row.
getIntervalMonthDayNanoObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a PeriodDuration from the column with the given index at the current row.
getIntervalMonthDayNanoVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getIntervalMonthDayNanoVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIntervalMonthDayNanoVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIntervalYear(String) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column of the given name at the current row.
getIntervalYear(int) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column with the given index at the current row.
getIntervalYear(String, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getIntervalYear(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getIntervalYearObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a Period from the column of the given name at the current row.
getIntervalYearObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a Period from the column with the given index at the current row.
getIntervalYearVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getIntervalYearVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIntervalYearVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIntVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getIsSigned() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
getJdbcConsumerGetter() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Gets the JDBC consumer getter.
getJdbcMajorVersion() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
getJdbcMinorVersion() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
getJdbcToArrowTypeConverter() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Gets the mapping between JDBC type information to Arrow type.
getJdbcType() - Method in class org.apache.arrow.adapter.jdbc.binder.BaseColumnBinder
 
getJdbcType() - Method in interface org.apache.arrow.adapter.jdbc.binder.ColumnBinder
Get the JDBC type code used by this binder.
getJdbcType() - Method in class org.apache.arrow.adapter.jdbc.binder.NullableColumnBinder
 
getJdbcType() - Method in class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
The Types type.
getKey() - Method in class org.apache.arrow.memory.BufferLedger
 
getKey() - Method in interface org.apache.arrow.memory.ValueWithKeyIncluded
 
getKeysSorted() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
getLargeVarBinary(String) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column of the given name at the current row.
getLargeVarBinary(int) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column with the given index at the current row.
getLargeVarBinaryVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getLargeVarBinaryVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getLargeVarBinaryVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getLargeVarChar(String) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column of the given name at the current row.
getLargeVarChar(int) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column with the given index at the current row.
getLargeVarCharObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a String from the column of the given name at the current row.
getLargeVarCharObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a String from the column with the given index at the current row.
getLargeVarCharVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getLargeVarCharVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getLargeVarCharVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getLastMatch(V, VectorValueComparator<V>, V, int) - Static method in class org.apache.arrow.algorithm.search.VectorRangeSearcher
Search for the last occurrence of an element.
getLastSet() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the index of last non-null element in the vector.
getLastSet() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the index of last non-null element in the vector.
getLastSet() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getLastSet() - Method in class org.apache.arrow.vector.complex.ListVector
 
getLatestMetadata() - Method in class org.apache.arrow.flight.FlightStream
Get the most recent metadata sent from the server.
getLeft() - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
getLeftStart() - Method in class org.apache.arrow.vector.compare.Range
 
getLength() - Method in interface org.apache.arrow.memory.ReusableBuffer
Get the number of valid bytes in the data.
getLength() - Method in class org.apache.arrow.memory.util.ArrowBufPointer
 
getLength() - Method in class org.apache.arrow.vector.compare.Range
 
getLength() - Method in class org.apache.arrow.vector.ipc.message.ArrowFieldNode
 
getLength() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
getLength() - Method in class org.apache.arrow.vector.util.ReusableByteArray
Get the number of bytes in the byte array.
getLimit() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
 
getLimit() - Method in interface org.apache.arrow.memory.BufferAllocator
Return the current maximum limit this allocator imposes.
getList(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getList() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getList(String) - Method in class org.apache.arrow.vector.table.Row
Returns a List from the column of the given name at the current row.
getList(int) - Method in class org.apache.arrow.vector.table.Row
Returns a List from the column with the given index at the current row.
getListActionsMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getListener() - Method in interface org.apache.arrow.memory.BufferAllocator
Returns the allocation listener used by this allocator.
getListFlightsMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getListSize() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Get the fixed size for each list.
getListSize() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
getLocalDateTimeFromEpochMicro(long, String) - Static method in class org.apache.arrow.vector.util.DateUtility
Convert microseconds from epoch to a LocalDateTime with timeZone offset.
getLocalDateTimeFromEpochMicro(long) - Static method in class org.apache.arrow.vector.util.DateUtility
Convert microseconds from epoch to a LocalDateTime with UTC offset.
getLocalDateTimeFromEpochMilli(long, String) - Static method in class org.apache.arrow.vector.util.DateUtility
Convert milliseconds from epoch to a LocalDateTime with timeZone offset.
getLocalDateTimeFromEpochMilli(long) - Static method in class org.apache.arrow.vector.util.DateUtility
Convert milliseconds from epoch to a LocalDateTime with UTC offset.
getLocalDateTimeFromEpochNano(long, String) - Static method in class org.apache.arrow.vector.util.DateUtility
Convert nanoseconds from epoch to a LocalDateTime with timeZone offset.
getLocalDateTimeFromEpochNano(long) - Static method in class org.apache.arrow.vector.util.DateUtility
Convert nanoseconds from epoch to a LocalDateTime with UTC offset.
getLocation() - Method in class org.apache.arrow.flight.FlightServer
Get the location for this server.
getLocation(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
getLocation(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
A list of URIs where this ticket can be redeemed via DoGet().
getLocation(int) - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationBuilderList() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationCount() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationCount() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
A list of URIs where this ticket can be redeemed via DoGet().
getLocationCount() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationList() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationList() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
A list of URIs where this ticket can be redeemed via DoGet().
getLocationList() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationOrBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationOrBuilder(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
A list of URIs where this ticket can be redeemed via DoGet().
getLocationOrBuilder(int) - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationOrBuilderList() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
getLocationOrBuilderList() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
A list of URIs where this ticket can be redeemed via DoGet().
getLocationOrBuilderList() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
A list of URIs where this ticket can be redeemed via DoGet().
getLocations() - Method in class org.apache.arrow.flight.FlightEndpoint
 
getLoginTimeout() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
getLogWriter() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
getLong(int) - Method in class io.netty.buffer.NettyArrowBuf
 
getLong(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getLong() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getLong(long) - Method in class org.apache.arrow.memory.ArrowBuf
Get long value stored at a particular index in the underlying memory chunk this ArrowBuf has access to.
getLongHashCode(long) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
 
getLongToLocalDateTimeForVector(TimeStampVector, TimeZone) - Static method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getManagedBuffer() - Method in interface org.apache.arrow.memory.BufferManager
Get a managed buffer of indeterminate size.
getManagedBuffer(long) - Method in interface org.apache.arrow.memory.BufferManager
Get a managed buffer of at least a certain size.
getMap(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getMap() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getMap(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getMap(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getMap(int) - Method in class org.apache.arrow.vector.table.Row
Returns a Map from the column of the given vectorIndex at the current row.
getMap(String) - Method in class org.apache.arrow.vector.table.Row
Returns a Map from the column of the given name at the current row.
getMaxBinaryLiteralLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxCatalogNameLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxCharLiteralLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxColumnNameLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxColumnsInGroupBy() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxColumnsInIndex() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxColumnsInOrderBy() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxColumnsInSelect() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxColumnsInTable() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxConnections() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxCursorNameLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxIndexLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxProcedureNameLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxRowSize() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxSchemaNameLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxStatementLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxStatements() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxTableNameLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxTablesInSelect() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMaxUserNameLength() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getMessage() - Method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
Get the realized flatbuf Message metadata description.
getMessage() - Method in class org.apache.arrow.vector.ipc.message.MessageResult
Get the Message metadata.
getMessageBodyLength() - Method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
Get the length of the message body.
getMessageBuffer() - Method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
Get the buffer containing the raw message metadata bytes, not including the message body data.
getMessageLength() - Method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
Get the length of the message metadata in bytes, not including the body length.
getMessageType() - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
getMessageType() - Method in interface org.apache.arrow.vector.ipc.message.ArrowMessage
Returns the flatbuffer enum value indicating the type of the message.
getMessageType() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
getMeta() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightConnection
 
getMetaData() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getMetaData() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
Get custom metadata.
getMetaData() - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
getMetadata() - Method in class org.apache.arrow.vector.types.pojo.Field
 
getMetadata() - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
getMetadataLength() - Method in class org.apache.arrow.vector.ipc.message.ArrowBlock
 
getMetadataMap() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns the metadata map.
getMetadataVersion() - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
getMethod() - Method in class org.apache.arrow.vector.ipc.message.ArrowBodyCompression
 
getMiddleware(FlightServerMiddleware.Key<T>) - Method in interface org.apache.arrow.flight.FlightProducer.CallContext
Get the middleware instance of the given type for this call.
getMiddleware() - Method in interface org.apache.arrow.flight.FlightProducer.CallContext
Get an immutable map of middleware for this call.
getMilliseconds(ArrowBuf, int) - Static method in class org.apache.arrow.vector.IntervalDayVector
Given a data buffer, get the get the number of milliseconds stored at a particular position in the vector.
getMinorType() - Method in class org.apache.arrow.vector.BigIntVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.BitVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getMinorType() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UnionMapReader
Return the MinorType of the reader as MAP.
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
getMinorType() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getMinorType() - Method in class org.apache.arrow.vector.complex.ListVector
 
getMinorType() - Method in class org.apache.arrow.vector.complex.MapVector
 
getMinorType() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getMinorType() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
getMinorType() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getMinorType() - Method in class org.apache.arrow.vector.DateDayVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.DateMilliVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.Decimal256Vector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.DecimalVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.DurationVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getMinorType() - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.Float4Vector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.Float8Vector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.holders.DenseUnionHolder
 
getMinorType() - Method in class org.apache.arrow.vector.holders.UnionHolder
 
getMinorType() - Method in class org.apache.arrow.vector.IntervalDayVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.IntervalYearVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.IntVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.LargeVarCharVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.NullVector
 
getMinorType() - Method in class org.apache.arrow.vector.SmallIntVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeMicroVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeMilliVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeNanoVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeSecVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampMicroVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampMilliVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampNanoVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TimeStampSecVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.TinyIntVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.UInt1Vector
 
getMinorType() - Method in class org.apache.arrow.vector.UInt2Vector
 
getMinorType() - Method in class org.apache.arrow.vector.UInt4Vector
 
getMinorType() - Method in class org.apache.arrow.vector.UInt8Vector
 
getMinorType() - Method in interface org.apache.arrow.vector.ValueVector
 
getMinorType() - Method in class org.apache.arrow.vector.VarBinaryVector
Get minor type for this vector.
getMinorType() - Method in class org.apache.arrow.vector.VarCharVector
Get minor type for this vector.
getMinorTypeForArrowType(ArrowType) - Static method in class org.apache.arrow.vector.types.Types
Maps the ArrowType to the java implementations MinorType.
getMode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
getMonths(ArrowBuf, int) - Static method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Given a data buffer, get the number of months stored at a particular position in the vector.
getName() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
Name for the savepoint.
getName() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
Name for the savepoint.
getName() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequestOrBuilder
Name for the savepoint.
getName() - Method in interface org.apache.arrow.memory.BufferAllocator
Return the name of this allocator.
getName() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
getName() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
getName() - Method in class org.apache.arrow.vector.BaseValueVector
 
getName() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
getName() - Method in enum org.apache.arrow.vector.BufferLayout.BufferType
 
getName() - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
getName() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getName() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getName() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getName() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getName() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getName() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getName() - Method in class org.apache.arrow.vector.NullVector
 
getName() - Method in class org.apache.arrow.vector.types.pojo.Field
 
getName() - Method in interface org.apache.arrow.vector.ValueVector
Gets the name of the vector.
getNameBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
Name for the savepoint.
getNameBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
Name for the savepoint.
getNameBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequestOrBuilder
Name for the savepoint.
getNanoseconds(ArrowBuf, int) - Static method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Given a data buffer, get the get the number of nanoseconds stored at a particular position in the vector.
getNCharacterStream() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getNCharacterStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getNClob() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getNClob() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getNetworkTimeout() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getNewFieldWriter(ValueVector) - Method in enum org.apache.arrow.vector.types.Types.MinorType
 
getNewVector(String, FieldType, BufferAllocator) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
Construct a vector for the user type.
getNewVector(String, FieldType, BufferAllocator, CallBack) - Method in enum org.apache.arrow.vector.types.Types.MinorType
Constructs a new vector for the given type.
getNewVector(Field, BufferAllocator, CallBack) - Method in enum org.apache.arrow.vector.types.Types.MinorType
Constructs a new vector for the given type.
getNextValue() - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Special API to return next value - substitute of regular Map.values.iterator().next().
getNodes() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
Get the nodes in this record batch.
getNoOverflow(ArrowBuf, int) - Static method in class org.apache.arrow.vector.UInt1Vector
Given a data buffer, get the value stored at a particular position in the vector.
getNoOverflow(ArrowBuf, int) - Static method in class org.apache.arrow.vector.UInt4Vector
Given a data buffer, get the value stored at a particular position in the vector.
getNoOverflow(ArrowBuf, int) - Static method in class org.apache.arrow.vector.UInt8Vector
Given a data buffer, get the value stored at a particular position in the vector.
getNormalBufferCount() - Method in class io.netty.buffer.PooledByteBufAllocatorL
 
getNormalBufferSize() - Method in class io.netty.buffer.PooledByteBufAllocatorL
 
getNString() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getNString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getNullableCaseSensitiveStructWriterFactoryInstance() - Static method in class org.apache.arrow.vector.complex.impl.NullableStructWriterFactory
 
getNullableStructWriterFactory() - Method in class org.apache.arrow.vector.complex.impl.NullableCaseSensitiveStructWriter
 
getNullableStructWriterFactory() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
getNullableStructWriterFactory() - Method in class org.apache.arrow.vector.complex.impl.SingleCaseSensitiveStructWriter
 
getNullableStructWriterFactory() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
getNullableStructWriterFactoryInstance() - Static method in class org.apache.arrow.vector.complex.impl.NullableStructWriterFactory
 
getNullCount() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the number of elements that are null in the vector.
getNullCount() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the number of elements that are null in the vector.
getNullCount() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the number of elements that are null in the vector.
getNullCount(ArrowBuf, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Given a validity buffer, find the number of bits that are not set.
getNullCount() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getNullCount() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getNullCount() - Method in class org.apache.arrow.vector.complex.LargeListVector
Get the number of elements that are null in the vector.
getNullCount() - Method in class org.apache.arrow.vector.complex.ListVector
Get the number of elements that are null in the vector.
getNullCount() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getNullCount() - Method in class org.apache.arrow.vector.complex.StructVector
Return the number of null values in the vector.
getNullCount() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getNullCount() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getNullCount() - Method in class org.apache.arrow.vector.ipc.message.ArrowFieldNode
 
getNullCount() - Method in class org.apache.arrow.vector.NullVector
 
getNullCount() - Method in interface org.apache.arrow.vector.ValueVector
Returns number of null elements in the vector.
getNullCount() - Method in class org.apache.arrow.vector.ZeroVector
 
getNumber() - Method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
 
getNumber() - Method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
 
getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
 
getNumericFunctions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getObject(Map<String, Class<?>>) - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getObject(Class<T>) - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.ArrowFlightJdbcNullVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDurationVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcIntervalVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getObject(Map<String, Class<?>>) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getObject(Class<T>) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcFixedSizeListVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcLargeListVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcListVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcMapVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcStructVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getObject() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getObject(int) - Method in class org.apache.arrow.vector.BigIntVector
getObject(int) - Method in class org.apache.arrow.vector.BitVector
getObject(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getObject(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getObject(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
Get the element in the list vector at a particular index.
getObject(int) - Method in class org.apache.arrow.vector.complex.ListVector
Get the element in the list vector at a particular index.
getObject(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getObject(int) - Method in class org.apache.arrow.vector.complex.StructVector
 
getObject(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getObject(int) - Method in class org.apache.arrow.vector.DateDayVector
getObject(int) - Method in class org.apache.arrow.vector.DateMilliVector
getObject(int) - Method in class org.apache.arrow.vector.Decimal256Vector
getObject(int) - Method in class org.apache.arrow.vector.DecimalVector
getObject(int) - Method in class org.apache.arrow.vector.DurationVector
getObject(int) - Method in class org.apache.arrow.vector.ExtensionTypeVector
Get the extension object at the specified index.
getObject(int) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
getObject(int) - Method in class org.apache.arrow.vector.Float4Vector
getObject(int) - Method in class org.apache.arrow.vector.Float8Vector
getObject(int) - Method in class org.apache.arrow.vector.IntervalDayVector
getObject(int) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
getObject(int) - Method in class org.apache.arrow.vector.IntervalYearVector
getObject(int) - Method in class org.apache.arrow.vector.IntVector
getObject(int) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Get the variable length element at specified index as Text.
getObject(int) - Method in class org.apache.arrow.vector.LargeVarCharVector
Get the variable length element at specified index as Text.
getObject(int) - Method in class org.apache.arrow.vector.NullVector
 
getObject(int) - Method in class org.apache.arrow.vector.SmallIntVector
getObject(int) - Method in class org.apache.arrow.vector.TimeMicroVector
getObject(int) - Method in class org.apache.arrow.vector.TimeMilliVector
getObject(int) - Method in class org.apache.arrow.vector.TimeNanoVector
getObject(int) - Method in class org.apache.arrow.vector.TimeSecVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampMicroVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampMilliVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampNanoVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
getObject(int) - Method in class org.apache.arrow.vector.TimeStampSecVector
getObject(int) - Method in class org.apache.arrow.vector.TinyIntVector
getObject(int) - Method in class org.apache.arrow.vector.UInt1Vector
getObject(int) - Method in class org.apache.arrow.vector.UInt2Vector
getObject(int) - Method in class org.apache.arrow.vector.UInt4Vector
getObject(int) - Method in class org.apache.arrow.vector.UInt8Vector
getObject(int) - Method in interface org.apache.arrow.vector.ValueVector
Get friendly type object from the vector.
getObject(int) - Method in class org.apache.arrow.vector.VarBinaryVector
Get the variable length element at specified index as Text.
getObject(int) - Method in class org.apache.arrow.vector.VarCharVector
Get the variable length element at specified index as Text.
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.ArrowFlightJdbcNullVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDurationVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcIntervalVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcListVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcMapVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcStructVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getObjectClass() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getObjectNoOverflow(int) - Method in class org.apache.arrow.vector.UInt1Vector
Returns the value stored at index without the potential for overflow.
getObjectNoOverflow(int) - Method in class org.apache.arrow.vector.UInt4Vector
getObjectNoOverflow(int) - Method in class org.apache.arrow.vector.UInt8Vector
Returns the value stored at index without the potential for overflow.
getObjectNotNull(int) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as Decimal256Vector.getObject(int), but does not check for null.
getObjectNotNull(int) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.getObject(int) but does not check for null.
getObjectNotNull(int) - Method in class org.apache.arrow.vector.DurationVector
Same as DurationVector.getObject(int) but does not check for null.
getObjectNotNull(int) - Method in class org.apache.arrow.vector.IntervalDayVector
Same as IntervalDayVector.getObject(int) but does not check for null.
getOffset() - Method in class org.apache.arrow.memory.util.ArrowBufPointer
 
getOffset(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getOffset() - Method in class org.apache.arrow.vector.ipc.message.ArrowBlock
 
getOffset() - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
buffer that stores the offsets for elements in the vector.
getOffsetBuffer() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
buffer that stores the offsets for elements in the vector.
getOffsetBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
buffer that stores the offsets for elements in the vector.
getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.ListVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.StructVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getOffsetBuffer() - Method in class org.apache.arrow.vector.NullVector
 
getOffsetBuffer() - Method in interface org.apache.arrow.vector.ValueVector
Gets the underlying buffer associated with offset vector.
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the memory address of buffer that stores the offsets for elements in the vector.
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the memory address of buffer that stores the offsets for elements in the vector.
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the memory address of buffer that stores the offsets for elements in the vector.
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.ListVector
 
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.StructVector
 
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getOffsetBufferAddress() - Method in interface org.apache.arrow.vector.FieldVector
Gets the starting address of the underlying buffer associated with offset vector.
getOffsetBufferAddress() - Method in class org.apache.arrow.vector.NullVector
 
getOffsetBufferValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getOffsetBufferValueCapacity() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getOffsetVector() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Deprecated.
This API will be removed, as the current implementations no longer hold inner offset vectors.
getOffsetVector() - Method in class org.apache.arrow.vector.complex.LargeListVector
Deprecated.
This API will be removed, as the current implementations no longer hold inner offset vectors.
getOffsetVector() - Method in interface org.apache.arrow.vector.complex.RepeatedValueVector
Deprecated.
This API will be removed, as the current implementations no longer hold inner offset vectors.
getOrdered() - Method in class org.apache.arrow.flight.FlightInfo
 
getOrdered() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
FlightEndpoints are in the same order as the data.
getOrdered() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
FlightEndpoints are in the same order as the data.
getOrdered() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
FlightEndpoints are in the same order as the data.
getOrdinal(K) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
getOrdinal(K) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
Returns the ordinal corresponding to the given key.
getOrdinal(K) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
Returns the ordinal corresponding to the given key.
getOrdinal(K) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
getOutcomeDetails() - Method in exception org.apache.arrow.memory.OutOfMemoryException
 
getOutputDirectory() - Method in class org.apache.arrow.maven.plugins.BaseModuleInfoCompilerPlugin
 
getOutputDirectory() - Method in class org.apache.arrow.maven.plugins.ModuleInfoCompilerPlugin
 
getOutputDirectory() - Method in class org.apache.arrow.maven.plugins.ModuleInfoTestCompilerPlugin
 
getParameterSchema() - Method in interface org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.PreparedStatement
Gets the Schema of the parameters for this ArrowFlightSqlClientHandler.PreparedStatement.
getParameterSchema() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Returns the Schema of the parameters.
getParameterSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
If the query provided contained parameters, parameter_schema contains the schema of the expected parameters.
getParameterSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
If the query provided contained parameters, parameter_schema contains the schema of the expected parameters.
getParameterSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResultOrBuilder
If the query provided contained parameters, parameter_schema contains the schema of the expected parameters.
getParentAllocator() - Method in interface org.apache.arrow.memory.BufferAllocator
Returns the parent allocator.
getParentLogger() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
getParserForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
getParserForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
getPassword() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the host.
getPassword() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string password = 3;
getPassword() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
string password = 3;
getPassword() - Method in interface org.apache.arrow.flight.impl.Flight.BasicAuthOrBuilder
string password = 3;
getPasswordBytes() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string password = 3;
getPasswordBytes() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
string password = 3;
getPasswordBytes() - Method in interface org.apache.arrow.flight.impl.Flight.BasicAuthOrBuilder
string password = 3;
getPath() - Method in class org.apache.arrow.flight.FlightDescriptor
 
getPath(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
getPath(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
List of strings identifying a particular dataset.
getPath(int) - Method in interface org.apache.arrow.flight.impl.Flight.FlightDescriptorOrBuilder
List of strings identifying a particular dataset.
getPathBytes(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
getPathBytes(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
List of strings identifying a particular dataset.
getPathBytes(int) - Method in interface org.apache.arrow.flight.impl.Flight.FlightDescriptorOrBuilder
List of strings identifying a particular dataset.
getPathCount() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
getPathCount() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
List of strings identifying a particular dataset.
getPathCount() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDescriptorOrBuilder
List of strings identifying a particular dataset.
getPathList() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
getPathList() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
List of strings identifying a particular dataset.
getPathList() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDescriptorOrBuilder
List of strings identifying a particular dataset.
getPayload() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
Arbitrary auth/handshake info.
getPayload() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
Arbitrary auth/handshake info.
getPayload() - Method in interface org.apache.arrow.flight.impl.Flight.HandshakeRequestOrBuilder
Arbitrary auth/handshake info.
getPayload() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
Arbitrary auth/handshake info.
getPayload() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
Arbitrary auth/handshake info.
getPayload() - Method in interface org.apache.arrow.flight.impl.Flight.HandshakeResponseOrBuilder
Arbitrary auth/handshake info.
getPeakMemoryAllocation() - Method in interface org.apache.arrow.memory.BufferAllocator
Returns the peak amount of memory allocated from this allocator.
getPeerIdentity() - Method in interface org.apache.arrow.flight.auth2.CallHeaderAuthenticator.AuthResult
The peer identity that was determined by the handshake process based on the authentication credentials supplied by the client.
getPeriod() - Method in class org.apache.arrow.vector.PeriodDuration
 
getPkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the parent table is.
getPkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The catalog name where the parent table is.
getPkCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The catalog name where the parent table is.
getPkCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the parent table is.
getPkCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The catalog name where the parent table is.
getPkCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The catalog name where the parent table is.
getPkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The Schema name where the parent table is.
getPkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The Schema name where the parent table is.
getPkDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The Schema name where the parent table is.
getPkDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The Schema name where the parent table is.
getPkDbSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The Schema name where the parent table is.
getPkDbSchemaBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The Schema name where the parent table is.
getPkTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The parent table name.
getPkTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The parent table name.
getPkTable() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The parent table name.
getPkTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The parent table name.
getPkTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The parent table name.
getPkTableBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The parent table name.
getPlan() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.SubstraitPlan
 
getPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
getPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
The serialized substrait.Plan to create a prepared statement for.
getPlan() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequestOrBuilder
The serialized substrait.Plan to create a prepared statement for.
getPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
getPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
A serialized substrait.Plan
getPlan() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlanOrBuilder
A serialized substrait.Plan
getPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The serialized substrait.Plan to create a prepared statement for.
getPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
The serialized substrait.Plan to create a prepared statement for.
getPlan() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlanOrBuilder
The serialized substrait.Plan to create a prepared statement for.
getPlanBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
getPlanBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
getPlanOrBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
getPlanOrBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
The serialized substrait.Plan to create a prepared statement for.
getPlanOrBuilder() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequestOrBuilder
The serialized substrait.Plan to create a prepared statement for.
getPlanOrBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
getPlanOrBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
A serialized substrait.Plan
getPlanOrBuilder() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlanOrBuilder
A serialized substrait.Plan
getPollFlightInfoMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getPooledConnection() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcConnectionPoolDataSource
 
getPooledConnection(String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcConnectionPoolDataSource
 
getPort() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the port.
getPort() - Method in class org.apache.arrow.flight.FlightServer
Get the port the server is running on (if applicable).
getPosition() - Method in interface org.apache.arrow.vector.complex.Positionable
 
getPossibleMemoryConsumed() - Method in class org.apache.arrow.memory.ArrowBuf
Returns the possible memory consumed by this ArrowBuf in the worse case scenario.
getPrecision() - Method in class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
The numeric precision, for Types.NUMERIC and Types.DECIMAL types.
getPrecision() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns the precision / column size.
getPrecision() - Method in class org.apache.arrow.vector.Decimal256Vector
Return precision for the decimal value.
getPrecision() - Method in class org.apache.arrow.vector.DecimalVector
Return precision for the decimal value.
getPrecision() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
getPrecision() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequestOrBuilder
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResultOrBuilder
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQueryOrBuilder
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
Opaque handle for the prepared statement on the server.
getPreparedStatementHandle() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdateOrBuilder
Opaque handle for the prepared statement on the server.
getPrimaryKeys(String, String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getPrimaryKeys(String, String, String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getPrimaryKeys" request based on the provided info.
getPrimaryKeys(TableRef, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request the primary keys for a table.
getPrimaryKeysSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
getPrimitiveVectors() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Get primitive child vectors.
getProcedureTerm() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getProgress() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Query progress.
getProgress() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
Query progress.
getProgress() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
Query progress.
getProgress() - Method in class org.apache.arrow.flight.PollInfo
The progress of the query.
getProperties(String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
Gets a copy of the ArrowFlightJdbcDataSource.properties for this ArrowFlightJdbcDataSource with the provided username and password.
getProperties() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcPooledConnection
 
getProtocolVersion() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
A defined protocol version
getProtocolVersion() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
A defined protocol version
getProtocolVersion() - Method in interface org.apache.arrow.flight.impl.Flight.HandshakeRequestOrBuilder
A defined protocol version
getProtocolVersion() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
A defined protocol version
getProtocolVersion() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
A defined protocol version
getProtocolVersion() - Method in interface org.apache.arrow.flight.impl.Flight.HandshakeResponseOrBuilder
A defined protocol version
getProvider() - Method in class org.apache.arrow.AvroToArrowConfig
 
getQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
The valid SQL string to create a prepared statement for.
getQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
The valid SQL string to create a prepared statement for.
getQuery() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequestOrBuilder
The valid SQL string to create a prepared statement for.
getQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
The SQL syntax.
getQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
The SQL syntax.
getQuery() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQueryOrBuilder
The SQL syntax.
getQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
The SQL syntax.
getQuery() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
The SQL syntax.
getQuery() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdateOrBuilder
The SQL syntax.
getQueryBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
The valid SQL string to create a prepared statement for.
getQueryBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
The valid SQL string to create a prepared statement for.
getQueryBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequestOrBuilder
The valid SQL string to create a prepared statement for.
getQueryBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
The SQL syntax.
getQueryBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
The SQL syntax.
getQueryBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQueryOrBuilder
The SQL syntax.
getQueryBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
The SQL syntax.
getQueryBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
The SQL syntax.
getQueryBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdateOrBuilder
The SQL syntax.
GetReadableBuffer - Class in org.apache.arrow.flight.grpc
Enable access to ReadableBuffer directly to copy data from a BufferInputStream into a target ByteBuffer/ByteBuf.
GetReadableBuffer() - Constructor for class org.apache.arrow.flight.grpc.GetReadableBuffer
 
getReadableBuffer(InputStream) - Static method in class org.apache.arrow.flight.grpc.GetReadableBuffer
Extracts the ReadableBuffer for the given input stream.
getReader() - Method in class org.apache.arrow.flight.FlightClient.ExchangeReaderWriter
Get the reader for the call.
getReader() - Method in class org.apache.arrow.vector.BaseValueVector
Default implementation to create a reader for the vector.
getReader() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getReader() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getReader() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getReader() - Method in class org.apache.arrow.vector.complex.ListVector
 
getReader() - Method in class org.apache.arrow.vector.complex.MapVector
Get the reader for this MapVector instance.
getReader() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getReader() - Method in class org.apache.arrow.vector.complex.StructVector
 
getReader() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getReader() - Method in class org.apache.arrow.vector.NullVector
 
getReader(String) - Method in class org.apache.arrow.vector.table.BaseTable
Returns a FieldReader for the vector with the given name.
getReader(Field) - Method in class org.apache.arrow.vector.table.BaseTable
Returns a FieldReader for the given field.
getReader(int) - Method in class org.apache.arrow.vector.table.BaseTable
Returns a FieldReader for the field at the given vector index.
getReader() - Method in interface org.apache.arrow.vector.ValueVector
Get a reader for this vector.
getReaderImpl() - Method in class org.apache.arrow.vector.BaseValueVector
Each vector has a different reader that implements the FieldReader interface.
getReaderImpl() - Method in class org.apache.arrow.vector.BigIntVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.BitVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.complex.ListVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.DateDayVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.DateMilliVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.Decimal256Vector
 
getReaderImpl() - Method in class org.apache.arrow.vector.DecimalVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.DurationVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.Float4Vector
 
getReaderImpl() - Method in class org.apache.arrow.vector.Float8Vector
 
getReaderImpl() - Method in class org.apache.arrow.vector.IntervalDayVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.IntervalYearVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.IntVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.LargeVarBinaryVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.LargeVarCharVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.SmallIntVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeMicroVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeMilliVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeNanoVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeSecVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampMicroVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampMilliVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampNanoVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampSecTZVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TimeStampSecVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.TinyIntVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.UInt1Vector
 
getReaderImpl() - Method in class org.apache.arrow.vector.UInt2Vector
 
getReaderImpl() - Method in class org.apache.arrow.vector.UInt4Vector
 
getReaderImpl() - Method in class org.apache.arrow.vector.UInt8Vector
 
getReaderImpl() - Method in class org.apache.arrow.vector.VarBinaryVector
 
getReaderImpl() - Method in class org.apache.arrow.vector.VarCharVector
 
getRecordBatch() - Method in class org.apache.arrow.vector.VectorUnloader
Performs the depth first traversal of the Vectors to create an ArrowRecordBatch suitable for serialization.
getRecordBatches() - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
getRecordBlocks() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
Returns the ArrowBlock metadata from the file.
getRecordBlocks() - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
 
getRecordCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
The number of records updated.
getRecordCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
The number of records updated.
getRecordCount() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResultOrBuilder
The number of records updated.
getRecords() - Method in class org.apache.arrow.flight.FlightInfo
 
getRecordsPerBatch() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int32 records_per_batch = 4;
getRecordsPerBatch() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
int32 records_per_batch = 4;
getRecordsPerBatch() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.PerfOrBuilder
int32 records_per_batch = 4;
getRecordsPerStream() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int64 records_per_stream = 3;
getRecordsPerStream() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
int64 records_per_stream = 3;
getRecordsPerStream() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.PerfOrBuilder
int64 records_per_stream = 3;
getRef() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getRef() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getRefCount() - Method in class org.apache.arrow.memory.BufferLedger
Get this ledger's reference count.
getRefCount() - Method in interface org.apache.arrow.memory.ReferenceManager
Return the reference count.
getReferenceManager() - Method in class org.apache.arrow.memory.ArrowBuf
Get reference manager for this ArrowBuf.
getRequestedSize() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
 
getResult() - Method in class org.apache.arrow.flight.AsyncPutListener
Wait for the stream to finish on the server side.
getResult() - Method in interface org.apache.arrow.flight.FlightClient.ClientStreamListener
Wait for the stream to finish on the server side.
getResult() - Method in class org.apache.arrow.flight.FlightClient.ExchangeReaderWriter
Make sure stream is drained.
getResult() - Method in interface org.apache.arrow.flight.FlightClient.PutListener
Wait for the stream to finish on the server side.
getResult() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
getResult() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
getResult() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResultOrBuilder
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
getResult() - Method in class org.apache.arrow.flight.SyncPutListener
 
getResultSet() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getResultSet(Map<String, Class<?>>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getResultSet(long, int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getResultSet(long, int, Map<String, Class<?>>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
getResultSetSchema() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Returns the Schema of the resultset.
getResultValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
getResultValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
getResultValue() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResultOrBuilder
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
getRight() - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
getRightStart() - Method in class org.apache.arrow.vector.compare.Range
 
getRoot() - Method in class org.apache.arrow.flight.FlightStream
Get the current vector data from the stream.
getRoot() - Method in interface org.apache.arrow.memory.BufferAllocator
Get the root allocator of this allocator.
getRootAsBinary(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Binary
 
getRootAsBinary(ByteBuffer, Binary) - Static method in class org.apache.arrow.flatbuf.Binary
 
getRootAsBinaryView(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.BinaryView
 
getRootAsBinaryView(ByteBuffer, BinaryView) - Static method in class org.apache.arrow.flatbuf.BinaryView
 
getRootAsBodyCompression(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
getRootAsBodyCompression(ByteBuffer, BodyCompression) - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
getRootAsBool(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Bool
 
getRootAsBool(ByteBuffer, Bool) - Static method in class org.apache.arrow.flatbuf.Bool
 
getRootAsDate(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Date
 
getRootAsDate(ByteBuffer, Date) - Static method in class org.apache.arrow.flatbuf.Date
 
getRootAsDecimal(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Decimal
 
getRootAsDecimal(ByteBuffer, Decimal) - Static method in class org.apache.arrow.flatbuf.Decimal
 
getRootAsDictionaryBatch(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
getRootAsDictionaryBatch(ByteBuffer, DictionaryBatch) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
getRootAsDictionaryEncoding(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
getRootAsDictionaryEncoding(ByteBuffer, DictionaryEncoding) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
getRootAsDuration(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Duration
 
getRootAsDuration(ByteBuffer, Duration) - Static method in class org.apache.arrow.flatbuf.Duration
 
getRootAsField(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Field
 
getRootAsField(ByteBuffer, Field) - Static method in class org.apache.arrow.flatbuf.Field
 
getRootAsFixedSizeBinary(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
getRootAsFixedSizeBinary(ByteBuffer, FixedSizeBinary) - Static method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
getRootAsFixedSizeList(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.FixedSizeList
 
getRootAsFixedSizeList(ByteBuffer, FixedSizeList) - Static method in class org.apache.arrow.flatbuf.FixedSizeList
 
getRootAsFloatingPoint(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.FloatingPoint
 
getRootAsFloatingPoint(ByteBuffer, FloatingPoint) - Static method in class org.apache.arrow.flatbuf.FloatingPoint
 
getRootAsFooter(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Footer
 
getRootAsFooter(ByteBuffer, Footer) - Static method in class org.apache.arrow.flatbuf.Footer
 
getRootAsInt(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Int
 
getRootAsInt(ByteBuffer, Int) - Static method in class org.apache.arrow.flatbuf.Int
 
getRootAsInterval(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Interval
 
getRootAsInterval(ByteBuffer, Interval) - Static method in class org.apache.arrow.flatbuf.Interval
 
getRootAsKeyValue(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.KeyValue
 
getRootAsKeyValue(ByteBuffer, KeyValue) - Static method in class org.apache.arrow.flatbuf.KeyValue
 
getRootAsLargeBinary(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.LargeBinary
 
getRootAsLargeBinary(ByteBuffer, LargeBinary) - Static method in class org.apache.arrow.flatbuf.LargeBinary
 
getRootAsLargeList(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.LargeList
 
getRootAsLargeList(ByteBuffer, LargeList) - Static method in class org.apache.arrow.flatbuf.LargeList
 
getRootAsLargeListView(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.LargeListView
 
getRootAsLargeListView(ByteBuffer, LargeListView) - Static method in class org.apache.arrow.flatbuf.LargeListView
 
getRootAsLargeUtf8(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.LargeUtf8
 
getRootAsLargeUtf8(ByteBuffer, LargeUtf8) - Static method in class org.apache.arrow.flatbuf.LargeUtf8
 
getRootAsList(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.List
 
getRootAsList(ByteBuffer, List) - Static method in class org.apache.arrow.flatbuf.List
 
getRootAsListView(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.ListView
 
getRootAsListView(ByteBuffer, ListView) - Static method in class org.apache.arrow.flatbuf.ListView
 
getRootAsMap(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Map
 
getRootAsMap(ByteBuffer, Map) - Static method in class org.apache.arrow.flatbuf.Map
 
getRootAsMessage(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Message
 
getRootAsMessage(ByteBuffer, Message) - Static method in class org.apache.arrow.flatbuf.Message
 
getRootAsNull(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Null
 
getRootAsNull(ByteBuffer, Null) - Static method in class org.apache.arrow.flatbuf.Null
 
getRootAsRecordBatch(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
getRootAsRecordBatch(ByteBuffer, RecordBatch) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
getRootAsRunEndEncoded(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.RunEndEncoded
 
getRootAsRunEndEncoded(ByteBuffer, RunEndEncoded) - Static method in class org.apache.arrow.flatbuf.RunEndEncoded
 
getRootAsSchema(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Schema
 
getRootAsSchema(ByteBuffer, Schema) - Static method in class org.apache.arrow.flatbuf.Schema
 
getRootAsSparseMatrixIndexCSX(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
getRootAsSparseMatrixIndexCSX(ByteBuffer, SparseMatrixIndexCSX) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
getRootAsSparseTensor(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
getRootAsSparseTensor(ByteBuffer, SparseTensor) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
getRootAsSparseTensorIndexCOO(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
getRootAsSparseTensorIndexCOO(ByteBuffer, SparseTensorIndexCOO) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
getRootAsSparseTensorIndexCSF(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
getRootAsSparseTensorIndexCSF(ByteBuffer, SparseTensorIndexCSF) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
getRootAsStruct_(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Struct_
 
getRootAsStruct_(ByteBuffer, Struct_) - Static method in class org.apache.arrow.flatbuf.Struct_
 
getRootAsTensor(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Tensor
 
getRootAsTensor(ByteBuffer, Tensor) - Static method in class org.apache.arrow.flatbuf.Tensor
 
getRootAsTensorDim(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.TensorDim
 
getRootAsTensorDim(ByteBuffer, TensorDim) - Static method in class org.apache.arrow.flatbuf.TensorDim
 
getRootAsTime(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Time
 
getRootAsTime(ByteBuffer, Time) - Static method in class org.apache.arrow.flatbuf.Time
 
getRootAsTimestamp(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Timestamp
 
getRootAsTimestamp(ByteBuffer, Timestamp) - Static method in class org.apache.arrow.flatbuf.Timestamp
 
getRootAsUnion(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Union
 
getRootAsUnion(ByteBuffer, Union) - Static method in class org.apache.arrow.flatbuf.Union
 
getRootAsUtf8(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Utf8
 
getRootAsUtf8(ByteBuffer, Utf8) - Static method in class org.apache.arrow.flatbuf.Utf8
 
getRootAsUtf8View(ByteBuffer) - Static method in class org.apache.arrow.flatbuf.Utf8View
 
getRootAsUtf8View(ByteBuffer, Utf8View) - Static method in class org.apache.arrow.flatbuf.Utf8View
 
getRoundedSize(long) - Method in class org.apache.arrow.memory.rounding.DefaultRoundingPolicy
 
getRoundedSize(long) - Method in interface org.apache.arrow.memory.rounding.RoundingPolicy
 
getRoundedSize(long) - Method in class org.apache.arrow.memory.rounding.SegmentRoundingPolicy
 
getRoundingPolicy() - Method in interface org.apache.arrow.memory.BufferAllocator
Gets the rounding policy of the allocator.
getRowCount() - Method in class org.apache.arrow.vector.table.BaseTable
Returns the number of rows in this table.
getRowCount() - Method in class org.apache.arrow.vector.VectorSchemaRoot
 
getRowNumber() - Method in class org.apache.arrow.vector.table.Row
 
getRunCount() - Method in class org.apache.arrow.algorithm.deduplicate.VectorRunDeduplicator
Gets the number of values which are different from their predecessor.
getSavepointId() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.Savepoint
 
getSavepointId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
Opaque handle for the savepoint on the server.
getSavepointId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
Opaque handle for the savepoint on the server.
getSavepointId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResultOrBuilder
Opaque handle for the savepoint on the server.
getSavepointId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Opaque handle for the savepoint on the server.
getSavepointId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
Opaque handle for the savepoint on the server.
getSavepointId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequestOrBuilder
Opaque handle for the savepoint on the server.
getScale() - Method in class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
The numeric scale, for Types.NUMERIC and Types.DECIMAL types.
getScale() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns the scale / decimal digits.
getScale() - Method in class org.apache.arrow.vector.Decimal256Vector
Return scale for the decimal value.
getScale() - Method in class org.apache.arrow.vector.DecimalVector
Return scale for the decimal value.
getScale() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
getSchema() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getSchema(FlightDescriptor, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Get schema for a stream.
getSchema() - Method in class org.apache.arrow.flight.FlightInfo
Deprecated.
Deprecated. Use FlightInfo.getSchemaOptional() instead.
getSchema(FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.FlightProducer
Get schema for a particular data stream.
getSchema() - Method in class org.apache.arrow.flight.FlightStream
Get the schema for this stream.
getSchema() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
getSchema() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
getSchema() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
getSchema() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
getSchema() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
getSchema() - Method in interface org.apache.arrow.flight.impl.Flight.SchemaResultOrBuilder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
getSchema(Flight.FlightDescriptor, StreamObserver<Flight.SchemaResult>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
For a given FlightDescriptor, get the Schema as described in Schema.fbs::Schema This is used when a consumer needs the Schema of flight stream.
getSchema(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
For a given FlightDescriptor, get the Schema as described in Schema.fbs::Schema This is used when a consumer needs the Schema of flight stream.
getSchema(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceFutureStub
For a given FlightDescriptor, get the Schema as described in Schema.fbs::Schema This is used when a consumer needs the Schema of flight stream.
getSchema(Flight.FlightDescriptor, StreamObserver<Flight.SchemaResult>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
For a given FlightDescriptor, get the Schema as described in Schema.fbs::Schema This is used when a consumer needs the Schema of flight stream.
getSchema() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
bytes schema = 1;
getSchema() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
bytes schema = 1;
getSchema() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.PerfOrBuilder
bytes schema = 1;
getSchema() - Method in class org.apache.arrow.flight.SchemaResult
 
getSchema(FlightDescriptor, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get schema for a stream.
getSchema(FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns the schema of the result produced by the SQL query.
getSchema() - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
getSchema() - Method in class org.apache.arrow.vector.table.BaseTable
Returns the schema for this Table.
getSchema(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.Schema
Adds this schema to the builder returning the size of the builder after adding.
getSchema() - Method in class org.apache.arrow.vector.VectorSchemaRoot
 
getSchemaChangedAndReset() - Method in class org.apache.arrow.vector.SchemaChangeCallBack
Returns the value of schema-changed state, resetting the schema-changed state to false.
getSchemaMetadata() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Return schema level metadata or null if not provided.
getSchemaName() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns the schema name.
getSchemaOptional() - Method in class org.apache.arrow.flight.FlightInfo
 
getSchemaPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getSchemaPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Get the schema of the result set of a prepared statement.
getSchemas(String, String) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getSchemas(String, String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getSchemas" request based on the provided info.
getSchemas(String, String, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a list of schemas.
getSchemasSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
getSchemaStatement(FlightSql.CommandStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getSchemaStatement(FlightSql.CommandStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Get the result schema for a SQL query.
getSchemaStatement(FlightSql.CommandStatementQuery, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getSchemaSubstraitPlan(FlightSql.CommandStatementSubstraitPlan, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getSchemaSubstraitPlan(FlightSql.CommandStatementSubstraitPlan, FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Get the result schema for a Substrait plan.
getSchemaTerm() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getSearchStringEscape() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getSegmentSize() - Method in class org.apache.arrow.memory.rounding.SegmentRoundingPolicy
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
getSerializedSize() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
getSerializedSize() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
getServiceDescriptor() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
getServiceDescriptor() - Static method in class org.apache.arrow.flight.TestServiceGrpc
 
getShort(int) - Method in class io.netty.buffer.NettyArrowBuf
 
getShort(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getShort() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getShort(long) - Method in class org.apache.arrow.memory.ArrowBuf
Get short value stored at a particular index in the underlying memory chunk this ArrowBuf has access to.
getSize() - Method in class org.apache.arrow.memory.AllocationManager
Return the size of underlying chunk of memory managed by this Allocation Manager.
getSize() - Method in interface org.apache.arrow.memory.AllocationReservation
Get the current size of the reservation (the sum of all the add()s).
getSize() - Method in class org.apache.arrow.memory.BufferLedger
Total size (in bytes) of memory underlying this reference manager.
getSize() - Method in class org.apache.arrow.memory.ForeignAllocation
Get the size of this allocation.
getSize() - Method in class org.apache.arrow.memory.NettyAllocationManager
Returns the underlying memory chunk size managed.
getSize() - Method in interface org.apache.arrow.memory.ReferenceManager
Total size (in bytes) of memory underlying this reference manager.
getSize() - Method in class org.apache.arrow.memory.UnsafeAllocationManager
 
getSize() - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
 
getSkipFieldNames() - Method in class org.apache.arrow.AvroToArrowConfig
 
getSmallInt(String) - Method in class org.apache.arrow.vector.table.Row
Returns a short from the column of the given name at the current row.
getSmallInt(int) - Method in class org.apache.arrow.vector.table.Row
Returns a short from the column with the given index at the current row.
getSmallInt(String, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getSmallInt(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getSmallIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getSmallIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getSmallIntVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getSourceRoots() - Method in class org.apache.arrow.maven.plugins.BaseModuleInfoCompilerPlugin
 
getSourceRoots() - Method in class org.apache.arrow.maven.plugins.ModuleInfoCompilerPlugin
 
getSourceRoots() - Method in class org.apache.arrow.maven.plugins.ModuleInfoTestCompilerPlugin
 
getSqlInfo(FlightSql.SqlInfo...) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Gets SQL info.
getSqlInfo(FlightSql.SqlInfo...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a set of Flight SQL metadata.
getSqlInfo(FlightSql.SqlInfo[], CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a set of Flight SQL metadata.
getSqlInfo(int[], CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a set of Flight SQL metadata.
getSqlInfo(Iterable<Integer>, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a set of Flight SQL metadata.
getSqlInfoSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of #getSqlInfo(SqlInfo...) from the server.
getSQLKeywords() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getSqlTypeIdFromArrowType(ArrowType) - Static method in class org.apache.arrow.driver.jdbc.utils.SqlTypes
Convert given ArrowType to its corresponding SQL type ID.
getSqlTypeNameFromArrowType(ArrowType) - Static method in class org.apache.arrow.driver.jdbc.utils.SqlTypes
Convert given ArrowType to its corresponding SQL type name.
getSQLXML() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getSQLXML() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getStart() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
inclusive start
getStart() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
inclusive start
getStart() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.TokenOrBuilder
inclusive start
getStartEnd(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the starting position (offset) in the data stream for a given element in the vector.
getStartOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcListVectorAccessor
 
getStartOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcFixedSizeListVectorAccessor
 
getStartOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcLargeListVectorAccessor
 
getStartOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcListVectorAccessor
 
getStartOffset(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcMapVectorAccessor
 
getStartOffset(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Gets the starting offset of a record, given its index.
getStartOffset(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
getStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
Unique identifier for the instance of the statement to execute.
getStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
Unique identifier for the instance of the statement to execute.
getStatementHandle() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQueryOrBuilder
Unique identifier for the instance of the statement to execute.
getStatus() - Method in class org.apache.arrow.flight.CancelFlightInfoResult
 
getStatus() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
.arrow.flight.protocol.CancelStatus status = 1;
getStatus() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
.arrow.flight.protocol.CancelStatus status = 1;
getStatus() - Method in interface org.apache.arrow.flight.impl.Flight.CancelFlightInfoResultOrBuilder
.arrow.flight.protocol.CancelStatus status = 1;
getStatus() - Method in class org.apache.arrow.memory.AllocationOutcome
Get the status of the allocation.
getStatusValue() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
.arrow.flight.protocol.CancelStatus status = 1;
getStatusValue() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
.arrow.flight.protocol.CancelStatus status = 1;
getStatusValue() - Method in interface org.apache.arrow.flight.impl.Flight.CancelFlightInfoResultOrBuilder
.arrow.flight.protocol.CancelStatus status = 1;
getStream() - Method in class org.apache.arrow.driver.jdbc.client.CloseableEndpointStreamPair
 
getStream(Ticket, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Retrieve a stream from the server.
getStream(FlightProducer.CallContext, Ticket, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.FlightProducer
Return data for a stream.
getStream(FlightProducer.CallContext, Ticket, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.IntegrationProducer
 
getStream(FlightProducer.CallContext, Ticket, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.NoOpFlightProducer
 
getStream(Ticket, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Retrieve a stream from the server.
getStream(FlightProducer.CallContext, Ticket, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Depending on the provided command, method either: 1.
getStreamCatalogs(FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamCatalogs(FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for catalogs based data stream.
getStreamCatalogs(FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamCount() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int32 stream_count = 2;
getStreamCount() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
int32 stream_count = 2;
getStreamCount() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.PerfOrBuilder
int32 stream_count = 2;
getStreamCrossReference(FlightSql.CommandGetCrossReference, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamCrossReference(FlightSql.CommandGetCrossReference, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for cross reference based data stream.
getStreamCrossReference(FlightSql.CommandGetCrossReference, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamExportedKeys(FlightSql.CommandGetExportedKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamExportedKeys(FlightSql.CommandGetExportedKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for foreign keys based data stream.
getStreamExportedKeys(FlightSql.CommandGetExportedKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for foreign keys based data stream.
getStreamImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for a particular prepared statement query instance.
getStreamPreparedStatement(FlightSql.CommandPreparedStatementQuery, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamPrimaryKeys(FlightSql.CommandGetPrimaryKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamPrimaryKeys(FlightSql.CommandGetPrimaryKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for primary keys based data stream.
getStreamPrimaryKeys(FlightSql.CommandGetPrimaryKeys, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreams(FlightInfo) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getStream" request based on the provided FlightInfo object.
getStreamSchemas(FlightSql.CommandGetDbSchemas, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamSchemas(FlightSql.CommandGetDbSchemas, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for schemas based data stream.
getStreamSchemas(FlightSql.CommandGetDbSchemas, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for SQL info based data stream.
getStreamSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamStatement(FlightSql.TicketStatementQuery, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamStatement(FlightSql.TicketStatementQuery, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for a SQL query based data stream.
getStreamStatement(FlightSql.TicketStatementQuery, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamTables(FlightSql.CommandGetTables, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamTables(FlightSql.CommandGetTables, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for tables based data stream.
getStreamTables(FlightSql.CommandGetTables, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamTableTypes(FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamTableTypes(FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for table types based data stream.
getStreamTableTypes(FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getStreamTypeInfo(FlightSql.CommandGetXdbcTypeInfo, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
getStreamTypeInfo(FlightSql.CommandGetXdbcTypeInfo, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Returns data for type info based data stream.
getStreamTypeInfo(FlightSql.CommandGetXdbcTypeInfo, FlightProducer.CallContext, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcIntervalVectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBaseIntVectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcBitVectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcDecimalVectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat4VectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.numeric.ArrowFlightJdbcFloat8VectorAccessor
 
getString() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getString(Properties) - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
Gets the property as String.
getStringFunctions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getStruct() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getStruct() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getStruct() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcStructVectorAccessor
 
getStruct(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getStruct() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getStruct(int) - Method in class org.apache.arrow.vector.table.Row
Returns an Object from the column at vectorIndex at the current row.
getStruct(String) - Method in class org.apache.arrow.vector.table.Row
Returns an Object from the column of the given name at the current row.
getSystemFunctions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the foreign key table to get the foreign keys for.
getTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the foreign key table to get the foreign keys for.
getTable() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the foreign key table to get the foreign keys for.
getTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the primary key table to get the foreign keys for.
getTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the primary key table to get the foreign keys for.
getTable() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the primary key table to get the foreign keys for.
getTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the table to get the primary keys for.
getTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the table to get the primary keys for.
getTable() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the table to get the primary keys for.
getTable() - Method in class org.apache.arrow.flight.sql.util.TableRef
Retrieves the table from the object.
getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the foreign key table to get the foreign keys for.
getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the foreign key table to get the foreign keys for.
getTableBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the foreign key table to get the foreign keys for.
getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the primary key table to get the foreign keys for.
getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the primary key table to get the foreign keys for.
getTableBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the primary key table to get the foreign keys for.
getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the table to get the primary keys for.
getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the table to get the primary keys for.
getTableBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the table to get the primary keys for.
getTableName() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns the table name.
getTableNameFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for tables to search for.
getTableNameFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter pattern for tables to search for.
getTableNameFilterPattern() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter pattern for tables to search for.
getTableNameFilterPatternBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for tables to search for.
getTableNameFilterPatternBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter pattern for tables to search for.
getTableNameFilterPatternBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter pattern for tables to search for.
getTables(String, String, String, String[]) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getTables(String, String, String, List<String>, boolean) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getTables" request based on the provided info.
getTables(String, String, String, List<String>, boolean, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a list of tables.
getTablesSchema(boolean, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
getTableTypes() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getTableTypes() - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Makes an RPC "getTableTypes" request.
getTableTypes(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request a list of table types.
getTableTypes(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
getTableTypes(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter of table types which must match.
getTableTypes(int) - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter of table types which must match.
getTableTypesBytes(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
getTableTypesBytes(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter of table types which must match.
getTableTypesBytes(int) - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter of table types which must match.
getTableTypesCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
getTableTypesCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter of table types which must match.
getTableTypesCount() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter of table types which must match.
getTableTypesList() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
getTableTypesList() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter of table types which must match.
getTableTypesList() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter of table types which must match.
getTableTypesSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of FlightSqlClient.getTableTypes(CallOption...) from the server.
getTargetBatchSize() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Get the target batch size for partial read.
getTargetBatchSize() - Method in class org.apache.arrow.AvroToArrowConfig
 
getTestMethod() - Static method in class org.apache.arrow.flight.TestServiceGrpc
 
getTicket() - Method in class org.apache.arrow.flight.FlightEndpoint
 
getTicket() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
getTicket() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
Token used to retrieve this stream.
getTicket() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
Token used to retrieve this stream.
getTicket() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
bytes ticket = 1;
getTicket() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
bytes ticket = 1;
getTicket() - Method in interface org.apache.arrow.flight.impl.Flight.TicketOrBuilder
bytes ticket = 1;
getTicketBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
getTicketOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
getTicketOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
Token used to retrieve this stream.
getTicketOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
Token used to retrieve this stream.
getTime(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getTime(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getTime(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
 
getTime(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getTime(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getTimeDateFunctions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
getTimeFormatter() - Static method in class org.apache.arrow.vector.util.DateUtility
Returns time formatter used to parse time strings.
getTimeMicro(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeMicro(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeMicro(String, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeMicro(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeMicroVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeMicroVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeMicroVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeMilli(String) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column of the given name at the current row.
getTimeMilli(int) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column with the given index at the current row.
getTimeMilli(String, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeMilli(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeMilliObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column of the given name at the current row.
getTimeMilliObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column with the given index at the current row.
getTimeMilliVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeMilliVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeMilliVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeNano(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeNano(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeNano(String, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given name at the current row.
getTimeNano(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getTimeNanoVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeNanoVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeNanoVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeSec(String) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column of the given name at the current row.
getTimeSec(int) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column with the given index at the current row.
getTimeSec(String, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeSec(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeSecVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeSecVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeSecVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimestamp(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getTimestamp(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
 
getTimestamp(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getTimestamp(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
 
getTimestamp(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getTimestamp(Calendar) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getTimeStampMicro(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeStampMicro(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampMicro(String, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampMicro(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampMicroObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column of the given name at the current row.
getTimeStampMicroObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column with the given index at the current row.
getTimeStampMicroTZ(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeStampMicroTZ(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampMicroTZ(String, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampMicroTZ(int, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampMicroTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMicroTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMicroTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMicroVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeStampMicroVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMicroVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMilli(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeStampMilli(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampMilli(String, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampMilli(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampMilliObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column of the given name at the current row.
getTimeStampMilliObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column with the given index at the current row.
getTimeStampMilliTZ(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeStampMilliTZ(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampMilliTZ(String, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampMilliTZ(int, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampMilliTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMilliTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMilliTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMilliVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeStampMilliVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampMilliVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampNano(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeStampNano(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampNano(String, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampNano(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampNanoObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column of the given name at the current row.
getTimeStampNanoObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column with the given index at the current row.
getTimeStampNanoTZ(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeStampNanoTZ(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampNanoTZ(String, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampNanoTZ(int, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampNanoTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampNanoTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampNanoTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampNanoVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeStampNanoVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampNanoVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampSec(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getTimeStampSec(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampSec(String, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampSec(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampSecObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column of the given name at the current row.
getTimeStampSecObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a LocalDateTime from the column with the given index at the current row.
getTimeStampSecTZ(String) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampSecTZ(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getTimeStampSecTZ(String, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column of the given name at the current row.
getTimeStampSecTZ(int, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value from the column with the given index at the current row.
getTimeStampSecTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampSecTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampSecTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampSecVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTimeStampSecVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimeStampSecVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTimestampValue(long) - Static method in class org.apache.arrow.driver.jdbc.utils.DateTimeUtils
Converts Epoch millis to a Timestamp object.
getTimeUnitForVector(ValueVector) - Static method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcDateVectorAccessor
 
getTimeUnitForVector(TimeStampVector) - Static method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getTimeUnitForVector(ValueVector) - Static method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeVectorAccessor
 
getTimeZone() - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Get the time zone of the timestamps stored in this vector.
getTimeZone() - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Get the time zone of the timestamps stored in this vector.
getTimeZone() - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Get the time zone of the timestamps stored in this vector.
getTimeZone() - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Get the time zone of the timestamps stored in this vector.
getTimezone() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
getTimeZoneForVector(TimeStampVector) - Static method in class org.apache.arrow.driver.jdbc.accessor.impl.calendar.ArrowFlightJdbcTimeStampVectorAccessor
 
getTinyInt(String) - Method in class org.apache.arrow.vector.table.Row
Returns a byte from the column of the given name at the current row.
getTinyInt(int) - Method in class org.apache.arrow.vector.table.Row
Returns a byte from the column with the given index at the current row.
getTinyInt(String, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getTinyInt(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column at the given index and current row.
getTinyIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTinyIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTinyIntVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTlsRootCertificatesPath() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
 
getTlsRootCertificatesStream(String) - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Generates an InputStream that contains certificates for path-based TLS Root Certificates.
getTo() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector.StructTransferPair
 
getTo() - Method in class org.apache.arrow.vector.TimeStampVector.TransferImpl
 
getTo() - Method in interface org.apache.arrow.vector.util.TransferPair
 
getToken() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
 
getToken(String, String) - Method in interface org.apache.arrow.flight.auth.BasicServerAuthHandler.BasicAuthValidator
 
getToString(V, int, int) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Get the toString() representation of vector suitable for debugging.
getToString(V, int, int, BiFunction<V, Integer, Object>) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Get the toString() representation of vector suitable for debugging.
getTotalBytes() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
int64 total_bytes = 5;
getTotalBytes() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
int64 total_bytes = 5;
getTotalBytes() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
int64 total_bytes = 5;
getTotalMonths(ArrowBuf, int) - Static method in class org.apache.arrow.vector.IntervalYearVector
Given a data buffer, get the value stored at a particular position in the vector.
getTotalRecords() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
Set these to -1 if unknown.
getTotalRecords() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
Set these to -1 if unknown.
getTotalRecords() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
Set these to -1 if unknown.
getTransactionId() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.Transaction
 
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
The transaction to which a savepoint belongs.
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
The transaction to which a savepoint belongs.
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequestOrBuilder
The transaction to which a savepoint belongs.
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
Opaque handle for the transaction on the server.
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
Opaque handle for the transaction on the server.
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResultOrBuilder
Opaque handle for the transaction on the server.
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequestOrBuilder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequestOrBuilder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Opaque handle for the transaction on the server.
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
Opaque handle for the transaction on the server.
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequestOrBuilder
Opaque handle for the transaction on the server.
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQueryOrBuilder
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlanOrBuilder
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdateOrBuilder
Include the query as part of this transaction (if unset, the query is auto-committed).
getTransactionIsolation() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.BaseValueVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Construct a transfer pair of this vector and another vector of same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.BigIntVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.BigIntVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.BitVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.BitVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.ListVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.ListVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.ListVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.ListVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.MapVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.MapVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.MapVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.MapVector
 
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.StructVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.StructVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.StructVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.StructVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.StructVector
 
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.DateDayVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.DateDayVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.DateMilliVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.DateMilliVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.Decimal256Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.Decimal256Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.DecimalVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.DecimalVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.DurationVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.DurationVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.Float4Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.Float4Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.Float8Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.Float8Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.IntervalDayVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.IntervalDayVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.IntervalYearVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.IntervalYearVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.IntVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.IntVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.LargeVarCharVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.LargeVarCharVector
 
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.NullVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.NullVector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.NullVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.NullVector
 
getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.NullVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.SmallIntVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.SmallIntVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeMicroVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeMicroVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeMilliVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeMilliVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeNanoVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeNanoVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeSecVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeSecVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampSecVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TimeStampSecVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.TinyIntVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.TinyIntVector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt1Vector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.UInt1Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt2Vector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.UInt2Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt4Vector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.UInt4Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt8Vector
 
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.UInt8Vector
Construct a TransferPair comprising this and a target vector of the same type.
getTransferPair(BufferAllocator) - Method in interface org.apache.arrow.vector.ValueVector
To transfer quota responsibility.
getTransferPair(String, BufferAllocator) - Method in interface org.apache.arrow.vector.ValueVector
To transfer quota responsibility.
getTransferPair(Field, BufferAllocator) - Method in interface org.apache.arrow.vector.ValueVector
To transfer quota responsibility.
getTransferPair(String, BufferAllocator, CallBack) - Method in interface org.apache.arrow.vector.ValueVector
To transfer quota responsibility.
getTransferPair(Field, BufferAllocator, CallBack) - Method in interface org.apache.arrow.vector.ValueVector
To transfer quota responsibility.
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.VarBinaryVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.VarBinaryVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.VarCharVector
Construct a TransferPair comprising of this and a target vector of the same type.
getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.VarCharVector
 
getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.ZeroVector
 
getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.ZeroVector
 
getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.ZeroVector
 
getTransferredBuffer() - Method in class org.apache.arrow.memory.BufferLedger.TransferResult
 
getTransferredBuffer() - Method in class org.apache.arrow.memory.OwnershipTransferNOOP
 
getTransferredBuffer() - Method in interface org.apache.arrow.memory.OwnershipTransferResult
 
getTrustStorePassword() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the KeyStore password.
getTrustStorePath() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the KeyStore path.
getType() - Method in interface org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.PreparedStatement
Gets the Meta.StatementType of this ArrowFlightSqlClientHandler.PreparedStatement.
getType() - Method in class org.apache.arrow.flight.Action
 
getType() - Method in class org.apache.arrow.flight.ActionType
 
getType() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
string type = 1;
getType() - Method in class org.apache.arrow.flight.impl.Flight.Action
string type = 1;
getType() - Method in interface org.apache.arrow.flight.impl.Flight.ActionOrBuilder
string type = 1;
getType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string type = 1;
getType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
string type = 1;
getType() - Method in interface org.apache.arrow.flight.impl.Flight.ActionTypeOrBuilder
string type = 1;
getType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
getType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
getType() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDescriptorOrBuilder
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
getType() - Method in class org.apache.arrow.vector.BufferLayout
 
getType() - Method in enum org.apache.arrow.vector.compression.CompressionUtil.CodecType
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
getType(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
getType() - Method in class org.apache.arrow.vector.types.pojo.Field
 
getType() - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
getType() - Method in enum org.apache.arrow.vector.types.Types.MinorType
Returns the ArrowType equivalent of this type.
getTypeBitWidth() - Method in class org.apache.arrow.vector.BufferLayout
 
getTypeBuffer() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTypeBuffer() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTypeBufferAddress() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTypeBufferCount(ArrowType) - Static method in class org.apache.arrow.vector.TypeLayout
Gets the number of BufferLayouts for the given arrowType.
getTypeBytes() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
string type = 1;
getTypeBytes() - Method in class org.apache.arrow.flight.impl.Flight.Action
string type = 1;
getTypeBytes() - Method in interface org.apache.arrow.flight.impl.Flight.ActionOrBuilder
string type = 1;
getTypeBytes() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string type = 1;
getTypeBytes() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
string type = 1;
getTypeBytes() - Method in interface org.apache.arrow.flight.impl.Flight.ActionTypeOrBuilder
string type = 1;
getTypeForField(Field) - Static method in class org.apache.arrow.vector.types.pojo.ArrowType
 
getTypeId(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getTypeId() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
getTypeIds() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
getTypeLayout(ArrowType) - Static method in class org.apache.arrow.vector.TypeLayout
Constructs a new for the given arrowType.
getTypeMap() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getTypeName() - Method in class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
The type name as reported by the database.
getTypeName() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns the type name.
getTypeValue() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
getTypeValue() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
getTypeValue() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDescriptorOrBuilder
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
getTypeValue(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getTypeWidth() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
getUInt1(String) - Method in class org.apache.arrow.vector.table.Row
Returns a byte from the column of the given name at the current row.
getUInt1(int) - Method in class org.apache.arrow.vector.table.Row
Returns a byte from the column with the given index at the current row.
getUInt1(String, NullableUInt1Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getUInt1(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getUInt1Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getUInt1Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUInt1Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUInt2(String) - Method in class org.apache.arrow.vector.table.Row
Returns a char from the column of the given name at the current row.
getUInt2(int) - Method in class org.apache.arrow.vector.table.Row
Returns a char from the column with the given index at the current row.
getUInt2(String, NullableUInt2Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getUInt2(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getUInt2Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getUInt2Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUInt2Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUInt4(String) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column of the given name at the current row.
getUInt4(int) - Method in class org.apache.arrow.vector.table.Row
Returns an int from the column with the given index at the current row.
getUInt4(String, NullableUInt4Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value at the column of the given name at the current row.
getUInt4(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value at the column with the given index at the current row.
getUInt4Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getUInt4Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUInt4Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUInt8(String) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column of the given name at the current row.
getUInt8(int) - Method in class org.apache.arrow.vector.table.Row
Returns a long from the column with the given index at the current row.
getUInt8(String, NullableUInt8Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column of the given name at the current row.
getUInt8(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.table.Row
Updates the holder with the value in the column with the given index at the current row.
getUInt8Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getUInt8Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUInt8Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getUnderlyingVector() - Method in class org.apache.arrow.vector.ExtensionTypeVector
Get the underlying vector.
getUnicodeStream() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getUnicodeStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.binary.ArrowFlightJdbcBinaryVectorAccessor
 
getUnicodeStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getUnicodeStream() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.text.ArrowFlightJdbcVarCharVectorAccessor
 
getUnion(int) - Method in class org.apache.arrow.vector.table.Row
Returns an Object from the column with the given index at the current row.
getUnion(String) - Method in class org.apache.arrow.vector.table.Row
Returns an Object from the column of the given name at the current row.
getUnit() - Method in class org.apache.arrow.vector.DurationVector
Gets the time unit of the duration.
getUnit() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
getUnit() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
getUnit() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
getUnit() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
getUnit() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
getUnsignedInt(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getUnsignedShort(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
getUri() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
string uri = 1;
getUri() - Method in class org.apache.arrow.flight.impl.Flight.Location
string uri = 1;
getUri() - Method in interface org.apache.arrow.flight.impl.Flight.LocationOrBuilder
string uri = 1;
getUri() - Method in class org.apache.arrow.flight.Location
 
getUriBytes() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
string uri = 1;
getUriBytes() - Method in class org.apache.arrow.flight.impl.Flight.Location
string uri = 1;
getUriBytes() - Method in interface org.apache.arrow.flight.impl.Flight.LocationOrBuilder
string uri = 1;
getURL() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
getURL() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getUsed() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
 
getUser() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the host.
getUsername() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string username = 2;
getUsername() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
string username = 2;
getUsername() - Method in interface org.apache.arrow.flight.impl.Flight.BasicAuthOrBuilder
string username = 2;
getUsernameBytes() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string username = 2;
getUsernameBytes() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
string username = 2;
getUsernameBytes() - Method in interface org.apache.arrow.flight.impl.Flight.BasicAuthOrBuilder
string username = 2;
getUtcCalendar() - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Returns the instance of a {java.util.Calendar} with the UTC time zone and root locale.
getValidityBuffer() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get buffer that manages the validity (NULL or NON-NULL nature) of elements in the vector.
getValidityBuffer() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get buffer that manages the validity (NULL or NON-NULL nature) of elements in the vector.
getValidityBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get buffer that manages the validity (NULL or NON-NULL nature) of elements in the vector.
getValidityBuffer() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.complex.ListVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.complex.StructVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getValidityBuffer() - Method in class org.apache.arrow.vector.NullVector
 
getValidityBuffer() - Method in interface org.apache.arrow.vector.ValueVector
Gets the underlying buffer associated with validity vector.
getValidityBufferAddress() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the memory address of buffer that manages the validity (NULL or NON-NULL nature) of elements in the vector.
getValidityBufferAddress() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the memory address of buffer that manages the validity (NULL or NON-NULL nature) of elements in the vector.
getValidityBufferAddress() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the memory address of buffer that manages the validity (NULL or NON-NULL nature) of elements in the vector.
getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.ListVector
 
getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.StructVector
 
getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getValidityBufferAddress() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getValidityBufferAddress() - Method in interface org.apache.arrow.vector.FieldVector
Gets the starting address of the underlying buffer associated with validity vector.
getValidityBufferAddress() - Method in class org.apache.arrow.vector.NullVector
 
getValidityBufferSize(int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Compute the size of validity buffer required to manage a given number of elements in a vector.
getValidityBufferSizeFromCount(int) - Static method in class org.apache.arrow.vector.BaseValueVector
 
getValidityBufferValueCapacity() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
getValueAsDouble(int) - Method in class org.apache.arrow.vector.Float4Vector
 
getValueAsDouble(int) - Method in class org.apache.arrow.vector.Float8Vector
 
getValueAsDouble(int) - Method in interface org.apache.arrow.vector.FloatingPointVector
Gets the value at the given index.
getValueAsLong(int) - Method in interface org.apache.arrow.vector.BaseIntVector
Gets the value at index.
getValueAsLong(int) - Method in class org.apache.arrow.vector.BigIntVector
 
getValueAsLong(int) - Method in class org.apache.arrow.vector.IntVector
 
getValueAsLong(int) - Method in class org.apache.arrow.vector.SmallIntVector
 
getValueAsLong(int) - Method in class org.apache.arrow.vector.TinyIntVector
 
getValueAsLong(int) - Method in class org.apache.arrow.vector.UInt1Vector
 
getValueAsLong(int) - Method in class org.apache.arrow.vector.UInt2Vector
 
getValueAsLong(int) - Method in class org.apache.arrow.vector.UInt4Vector
 
getValueAsLong(int) - Method in class org.apache.arrow.vector.UInt8Vector
 
getValueBufferValueCapacity() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
getValueBufferValueCapacity() - Method in class org.apache.arrow.vector.BitVector
 
getValueCapacity() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the current value capacity for the vector.
getValueCapacity() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the current capacity which does not exceed either validity buffer or offset buffer.
getValueCapacity() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the current capacity which does not exceed either validity buffer or offset buffer.
getValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.LargeListVector
Get the current value capacity for the vector.
getValueCapacity() - Method in class org.apache.arrow.vector.complex.ListVector
Get the current value capacity for the vector.
getValueCapacity() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getValueCapacity() - Method in class org.apache.arrow.vector.complex.StructVector
Get the current value capacity for the vector.
getValueCapacity() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getValueCapacity() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter
 
getValueCapacity() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getValueCapacity() - Method in class org.apache.arrow.vector.NullVector
 
getValueCapacity() - Method in interface org.apache.arrow.vector.ValueVector
Returns the maximum number of values that can be stored in this vector instance.
getValueCapacity() - Method in class org.apache.arrow.vector.ZeroVector
 
getValueCount() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Get the value count of vector.
getValueCount() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the value count of vector.
getValueCount() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the value count of vector.
getValueCount() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
getValueCount() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getValueCount() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getValueCount() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getValueCount() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getValueCount() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getValueCount() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
getValueCount() - Method in class org.apache.arrow.vector.NullVector
 
getValueCount() - Method in interface org.apache.arrow.vector.ValueVector
Gets the number of values.
getValueCount() - Method in class org.apache.arrow.vector.ZeroVector
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
 
getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
 
getValueFromAuthHeader(CallHeaders, String) - Static method in class org.apache.arrow.flight.auth2.AuthUtilities
Helper method for retrieving a value from the Authorization header.
getValueLength(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Get the variable length element at specified index as Text.
getValueLength(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Get the variable length element at specified index as Text.
getValueWidth() - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
 
getVarBinary(String) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column of the given name at the current row.
getVarBinary(int) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column with the given index at the current row.
getVarBinaryVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getVarBinaryVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVarBinaryVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVarChar(String) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column of the given name at the current row.
getVarChar(int) - Method in class org.apache.arrow.vector.table.Row
Returns a byte[] from the column with the given index at the current row.
getVarCharObj(String) - Method in class org.apache.arrow.vector.table.Row
Returns a String from the column of the given name at the current row.
getVarCharObj(int) - Method in class org.apache.arrow.vector.table.Row
Returns a String from the column with the given index at the current row.
getVarCharVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getVarCharVector() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVarCharVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVector() - Method in class org.apache.arrow.adapter.jdbc.binder.BaseColumnBinder
 
getVector() - Method in interface org.apache.arrow.adapter.jdbc.binder.ColumnBinder
Get the vector used by this binder.
getVector() - Method in class org.apache.arrow.adapter.jdbc.binder.NullableColumnBinder
 
getVector() - Method in class org.apache.arrow.consumers.BaseAvroConsumer
 
getVector() - Method in interface org.apache.arrow.consumers.Consumer
Get the vector within the consumer.
getVector() - Method in class org.apache.arrow.consumers.SkipConsumer
 
getVector() - Method in class org.apache.arrow.vector.AddOrGetResult
Returns the vector.
getVector(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVector(int, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVector() - Method in class org.apache.arrow.vector.dictionary.Dictionary
 
getVector(String) - Method in class org.apache.arrow.vector.VectorSchemaRoot
gets a vector by name.
getVector(Field) - Method in class org.apache.arrow.vector.VectorSchemaRoot
 
getVector(int) - Method in class org.apache.arrow.vector.VectorSchemaRoot
 
getVectorById(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
getVectorById(int, Class<V>) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
Gets a child vector by ordinal position and casts to the specified class.
getVectorByType(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getVectorByType(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVectorByType(int, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
getVectorByTypeId(byte) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
getVectorByTypeId(byte) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcDenseUnionVectorAccessor
 
getVectorByTypeId(byte) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcUnionVectorAccessor
 
getVectorCopy(String) - Method in class org.apache.arrow.vector.table.BaseTable
Returns a copy of the vector with the given name, or throws IllegalArgumentException if the name is not found.
getVectorCopy(int) - Method in class org.apache.arrow.vector.table.BaseTable
Returns a copy of the vector at the given position.
getVectorCount() - Method in class org.apache.arrow.vector.table.BaseTable
Returns the number of vectors (columns) in this table.
getVectorSchemaRoot() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Returns the vector schema root.
getVectorType() - Method in class org.apache.arrow.vector.dictionary.Dictionary
 
getVersion() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.SubstraitPlan
 
getVersion() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The Substrait release, e.g.
getVersion() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
The Substrait release, e.g.
getVersion() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlanOrBuilder
The Substrait release, e.g.
getVersionBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The Substrait release, e.g.
getVersionBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
The Substrait release, e.g.
getVersionBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlanOrBuilder
The Substrait release, e.g.
getWarnings() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
getWriter() - Method in class org.apache.arrow.flight.FlightClient.ExchangeReaderWriter
Get the writer for the call.
getWriter() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
getWriter() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
getWriter(Types.MinorType, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
getWriter() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
getWriter() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
getWriter() - Method in class org.apache.arrow.vector.complex.ListVector
 
getWriter() - Method in class org.apache.arrow.vector.complex.MapVector
Get the writer for this MapVector instance.
getWriter() - Method in class org.apache.arrow.vector.complex.StructVector
 
getWriter() - Method in class org.apache.arrow.vector.complex.UnionVector
 
getXdbcTypeInfo(int, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request the information about the data types supported related to a filter data type.
getXdbcTypeInfo(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request the information about all the data types supported.
getXdbcTypeInfoSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Get the schema of FlightSqlClient.getXdbcTypeInfo(CallOption...) from the server.
GRPC - Static variable in class org.apache.arrow.flight.LocationSchemes
 
GRPC_DOMAIN_SOCKET - Static variable in class org.apache.arrow.flight.LocationSchemes
 
GRPC_INSECURE - Static variable in class org.apache.arrow.flight.LocationSchemes
 
GRPC_TLS - Static variable in class org.apache.arrow.flight.LocationSchemes
 

H

HALF - Static variable in class org.apache.arrow.flatbuf.Precision
 
handleCase(String) - Method in class org.apache.arrow.vector.complex.impl.NullableCaseSensitiveStructWriter
 
handleCase(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
handleCase(String) - Method in class org.apache.arrow.vector.complex.impl.SingleCaseSensitiveStructWriter
 
handleCase(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
handleSafe(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
handleSafe(int, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
handleSafe(int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
handshake(CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Executes the handshake against the Flight service.
handshake(StreamObserver<Flight.HandshakeResponse>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
Handshake between client and server.
handshake(StreamObserver<Flight.HandshakeResponse>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
Handshake between client and server.
HANDSHAKE_DESCRIPTOR_NAME - Static variable in class org.apache.arrow.flight.auth.AuthConstants
 
hasArray() - Method in class io.netty.buffer.NettyArrowBuf
 
hasAuthHandler() - Method in class org.apache.arrow.flight.auth.ClientAuthInterceptor
 
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies the Catalog to search for the tables.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
Specifies the Catalog to search for the tables.
hasCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemasOrBuilder
Specifies the Catalog to search for the tables.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the catalog to search for the foreign key table.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the catalog to search for the foreign key table.
hasCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the catalog to search for the foreign key table.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the catalog to search for the primary key table.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the catalog to search for the primary key table.
hasCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the catalog to search for the primary key table.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the catalog to search for the table.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the catalog to search for the table.
hasCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the catalog to search for the table.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies the Catalog to search for the tables.
hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies the Catalog to search for the tables.
hasCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies the Catalog to search for the tables.
hasDataType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
Specifies the data type to search for the info.
hasDataType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
Specifies the data type to search for the info.
hasDataType() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfoOrBuilder
Specifies the data type to search for the info.
hasDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the schema to search for the foreign key table.
hasDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
Specifies the schema to search for the foreign key table.
hasDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeysOrBuilder
Specifies the schema to search for the foreign key table.
hasDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the schema to search for the primary key table.
hasDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
Specifies the schema to search for the primary key table.
hasDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeysOrBuilder
Specifies the schema to search for the primary key table.
hasDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the schema to search for the table.
hasDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
Specifies the schema to search for the table.
hasDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeysOrBuilder
Specifies the schema to search for the table.
hasDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies a filter pattern for schemas to search for.
hasDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
Specifies a filter pattern for schemas to search for.
hasDbSchemaFilterPattern() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemasOrBuilder
Specifies a filter pattern for schemas to search for.
hasDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for schemas to search for.
hasDbSchemaFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter pattern for schemas to search for.
hasDbSchemaFilterPattern() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter pattern for schemas to search for.
hasDefinition() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
hasDefinition() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
definition of entire flight.
hasDefinition() - Method in interface org.apache.arrow.flight.perf.impl.PerfOuterClass.TokenOrBuilder
definition of entire flight.
hasEndpoint() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
hasEndpoint() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
hasEndpoint() - Method in interface org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequestOrBuilder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
hasExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
hasExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
Expiration time of this stream.
hasExpirationTime() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
Expiration time of this stream.
hasExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
hasExpirationTime() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
Expiration time for this request.
hasExpirationTime() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
Expiration time for this request.
hasFkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the foreign table is.
hasFkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The catalog name where the foreign table is.
hasFkCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The catalog name where the foreign table is.
hasFkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The schema name where the foreign table is.
hasFkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The schema name where the foreign table is.
hasFkDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The schema name where the foreign table is.
hasFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
hasFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
The descriptor of the data.
hasFlightDescriptor() - Method in interface org.apache.arrow.flight.impl.Flight.FlightDataOrBuilder
The descriptor of the data.
hasFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
hasFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
The descriptor associated with this info.
hasFlightDescriptor() - Method in interface org.apache.arrow.flight.impl.Flight.FlightInfoOrBuilder
The descriptor associated with this info.
hasFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
hasFlightDescriptor() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
The descriptor the client should use on the next try.
hasFlightDescriptor() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
The descriptor the client should use on the next try.
hash(ArrowBuf, long, long) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
Compute hashCode with the given ArrowBuf and start/end index.
hash(ArrowBufHasher, ArrowBuf, long, long) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
Compute hashCode with the given ArrowBufHasher, ArrowBuf and start/end index.
hashCode() - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
hashCode() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcTime
 
hashCode() - Method in class org.apache.arrow.flight.CancelFlightInfoResult
 
hashCode() - Method in class org.apache.arrow.flight.FlightDescriptor
 
hashCode() - Method in class org.apache.arrow.flight.FlightEndpoint
 
hashCode() - Method in class org.apache.arrow.flight.FlightInfo
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
hashCode() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
hashCode() - Method in class org.apache.arrow.flight.Location
 
hashCode() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
hashCode() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
hashCode() - Method in class org.apache.arrow.flight.PollInfo
 
hashCode() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.SubstraitPlan
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
hashCode() - Method in class org.apache.arrow.flight.Ticket
 
hashCode() - Method in class org.apache.arrow.memory.ArrowBuf
 
hashCode() - Method in class org.apache.arrow.memory.util.ArrowBufPointer
 
hashCode(long, long) - Method in interface org.apache.arrow.memory.util.hash.ArrowBufHasher
Calculates the hash code for a memory region.
hashCode(ArrowBuf, long, long) - Method in interface org.apache.arrow.memory.util.hash.ArrowBufHasher
Calculates the hash code for a memory region.
hashCode(long, long) - Method in class org.apache.arrow.memory.util.hash.MurmurHasher
 
hashCode(ArrowBuf, long, long) - Method in class org.apache.arrow.memory.util.hash.MurmurHasher
 
hashCode(ArrowBuf, long, long, int) - Static method in class org.apache.arrow.memory.util.hash.MurmurHasher
Calculates the hash code for a memory region.
hashCode(long, long, int) - Static method in class org.apache.arrow.memory.util.hash.MurmurHasher
Calculates the hash code for a memory region.
hashCode() - Method in class org.apache.arrow.memory.util.hash.MurmurHasher
 
hashCode(long, long) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
Calculates the hash code for a memory region.
hashCode(ArrowBuf, long, long) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
Calculates the hash code for a memory region.
hashCode() - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
 
hashCode(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
hashCode(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
hashCode(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
hashCode(int) - Method in class org.apache.arrow.vector.BitVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BitVector
 
hashCode() - Method in class org.apache.arrow.vector.BufferLayout
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
hashCode(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
hashCode(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
hashCode(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
hashCode(int) - Method in class org.apache.arrow.vector.complex.ListVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.ListVector
 
hashCode(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
hashCode(int) - Method in class org.apache.arrow.vector.complex.StructVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.StructVector
 
hashCode(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.UnionVector
 
hashCode() - Method in class org.apache.arrow.vector.dictionary.Dictionary
 
hashCode() - Method in class org.apache.arrow.vector.holders.BigIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.BitHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.DateDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.DateMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.Decimal256Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.DecimalHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.DurationHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.Float4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.Float8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.IntervalDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.IntervalYearHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.IntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.LargeVarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.LargeVarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableBigIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableBitHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableDateDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableDateMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableDecimal256Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableDecimalHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableDurationHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableFloat4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableFloat8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableIntervalDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableIntervalYearHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableSmallIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMicroTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMilliTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampNanoTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTimeStampSecTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableTinyIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableUInt1Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableUInt2Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableUInt4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableUInt8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableVarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.NullableVarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.SmallIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampMicroTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampMilliTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampNanoTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TimeStampSecTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.TinyIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.UInt1Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.UInt2Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.UInt4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.UInt8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.VarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.holders.VarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
hashCode() - Method in class org.apache.arrow.vector.ipc.message.ArrowBlock
 
hashCode() - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
 
hashCode() - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
hashCode(int) - Method in class org.apache.arrow.vector.NullVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.NullVector
 
hashCode() - Method in class org.apache.arrow.vector.PeriodDuration
 
hashCode() - Method in class org.apache.arrow.vector.TypeLayout
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.DictionaryEncoding
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.Field
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
hashCode() - Method in class org.apache.arrow.vector.types.pojo.Schema
 
hashCode() - Method in class org.apache.arrow.vector.util.ReusableByteArray
 
hashCode(int) - Method in interface org.apache.arrow.vector.ValueVector
Returns hashCode of element in index with the default hasher.
hashCode(int, ArrowBufHasher) - Method in interface org.apache.arrow.vector.ValueVector
Returns hashCode of element in index with the given hasher.
hashCode(int) - Method in class org.apache.arrow.vector.ZeroVector
 
hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.ZeroVector
 
HashTableBasedDictionaryBuilder<V extends ElementAddressableVector> - Class in org.apache.arrow.algorithm.dictionary
This class builds the dictionary based on a hash table.
HashTableBasedDictionaryBuilder(V) - Constructor for class org.apache.arrow.algorithm.dictionary.HashTableBasedDictionaryBuilder
Constructs a hash table based dictionary builder.
HashTableBasedDictionaryBuilder(V, boolean) - Constructor for class org.apache.arrow.algorithm.dictionary.HashTableBasedDictionaryBuilder
Constructs a hash table based dictionary builder.
HashTableBasedDictionaryBuilder(V, boolean, ArrowBufHasher) - Constructor for class org.apache.arrow.algorithm.dictionary.HashTableBasedDictionaryBuilder
Constructs a hash table based dictionary builder.
HashTableDictionaryEncoder<E extends BaseIntVector,D extends ElementAddressableVector> - Class in org.apache.arrow.algorithm.dictionary
Dictionary encoder based on hash table.
HashTableDictionaryEncoder(D) - Constructor for class org.apache.arrow.algorithm.dictionary.HashTableDictionaryEncoder
Constructs a dictionary encoder.
HashTableDictionaryEncoder(D, boolean) - Constructor for class org.apache.arrow.algorithm.dictionary.HashTableDictionaryEncoder
Constructs a dictionary encoder.
HashTableDictionaryEncoder(D, boolean, ArrowBufHasher) - Constructor for class org.apache.arrow.algorithm.dictionary.HashTableDictionaryEncoder
Constructs a dictionary encoder.
hasInfo() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
hasInfo() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
.arrow.flight.protocol.FlightInfo info = 1;
hasInfo() - Method in interface org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequestOrBuilder
.arrow.flight.protocol.FlightInfo info = 1;
hasInfo() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
hasInfo() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
The currently available results.
hasInfo() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
The currently available results.
hasMemoryAddress() - Method in class io.netty.buffer.NettyArrowBuf
 
hasNext() - Method in class org.apache.arrow.adapter.jdbc.ArrowVectorIterator
 
hasNext() - Method in class org.apache.arrow.AvroToArrowVectorIterator
 
hasNext() - Method in class org.apache.arrow.vector.table.Row
Returns true if there is at least one more non-deleted row in the table that has yet to be processed.
hasNext() - Method in class org.apache.arrow.vector.util.ElementAddressableVectorIterator
 
hasPkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the parent table is.
hasPkCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The catalog name where the parent table is.
hasPkCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The catalog name where the parent table is.
hasPkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The Schema name where the parent table is.
hasPkDbSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
The Schema name where the parent table is.
hasPkDbSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReferenceOrBuilder
The Schema name where the parent table is.
hasPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
hasPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
The serialized substrait.Plan to create a prepared statement for.
hasPlan() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequestOrBuilder
The serialized substrait.Plan to create a prepared statement for.
hasPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
hasPlan() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
A serialized substrait.Plan
hasPlan() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlanOrBuilder
A serialized substrait.Plan
hasProgress() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Query progress.
hasProgress() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
Query progress.
hasProgress() - Method in interface org.apache.arrow.flight.impl.Flight.PollInfoOrBuilder
Query progress.
hasRoot() - Method in class org.apache.arrow.flight.FlightStream
Check if there is a root (i.e.
hasTableNameFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for tables to search for.
hasTableNameFilterPattern() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
Specifies a filter pattern for tables to search for.
hasTableNameFilterPattern() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTablesOrBuilder
Specifies a filter pattern for tables to search for.
hasTicket() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
hasTicket() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
Token used to retrieve this stream.
hasTicket() - Method in interface org.apache.arrow.flight.impl.Flight.FlightEndpointOrBuilder
Token used to retrieve this stream.
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
hasTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequestOrBuilder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
hasTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequestOrBuilder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQueryOrBuilder
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlanOrBuilder
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
Include the query as part of this transaction (if unset, the query is auto-committed).
hasTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdateOrBuilder
Include the query as part of this transaction (if unset, the query is auto-committed).
header(Table) - Method in class org.apache.arrow.flatbuf.Message
 
HEADER_KEY - Static variable in interface org.apache.arrow.flight.FlightConstants
 
headerAuthenticator(CallHeaderAuthenticator) - Method in class org.apache.arrow.flight.FlightServer.Builder
Set the header-based authentication mechanism.
HeaderCallOption - Class in org.apache.arrow.flight
Method option for supplying headers to method calls.
HeaderCallOption(CallHeaders) - Constructor for class org.apache.arrow.flight.HeaderCallOption
Header property constructor.
headers() - Method in class org.apache.arrow.flight.ServerHeaderMiddleware
Retrieve the headers for this call.
headerType() - Method in class org.apache.arrow.flatbuf.Message
 
headerType() - Method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
 
heapBuffer() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
heapBuffer(int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
heapBuffer(int, int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
HelpMojo - Class in org.apache.arrow.maven.plugins
Display help information on module-info-compiler-maven-plugin.
Call mvn module-info-compiler:help -Ddetail=true -Dgoal=<goal-name> to display parameter details.
HelpMojo() - Constructor for class org.apache.arrow.maven.plugins.HelpMojo
 
HistoricalLog - Class in org.apache.arrow.memory.util
Utility class that can be used to log activity within a class for later logging and debugging.
HistoricalLog(String, Object...) - Constructor for class org.apache.arrow.memory.util.HistoricalLog
Constructor.
HistoricalLog(int, String, Object...) - Constructor for class org.apache.arrow.memory.util.HistoricalLog
Constructor.
hoursToMillis - Static variable in class org.apache.arrow.vector.util.DateUtility
 

I

id - Variable in class io.netty.buffer.UnsafeDirectLittleEndian
 
id() - Method in class org.apache.arrow.flatbuf.DictionaryBatch
 
id() - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
The known dictionary id in the application where this data is used.
idx() - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
idx() - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
immutableListCopy(List<V>) - Static method in class org.apache.arrow.util.Collections2
Copies the elements of list to a new unmodifiable list.
immutableMapCopy(Map<K, V>) - Static method in class org.apache.arrow.util.Collections2
Copies the elements of map to a new unmodifiable map.
immutableRow() - Method in class org.apache.arrow.vector.table.BaseTable
Returns an immutable Row object holding a reference to this table.
in - Variable in class org.apache.arrow.vector.ipc.message.MessageChannelReader
 
INCLUDE_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
incrementAllocationMonitor() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
indent(StringBuilder, int) - Static method in class org.apache.arrow.memory.util.CommonUtil
Specify an indentation amount when using a StringBuilder.
indexAtRank(V, VectorValueComparator<V>, int) - Method in class org.apache.arrow.algorithm.rank.VectorRank
Given a rank r, gets the index of the element that is the rth smallest in the vector.
indexSorter - Variable in class org.apache.arrow.algorithm.sort.FixedWidthOutOfPlaceVectorSorter
 
IndexSorter<V extends ValueVector> - Class in org.apache.arrow.algorithm.sort
Sorter for the indices of a vector.
IndexSorter() - Constructor for class org.apache.arrow.algorithm.sort.IndexSorter
 
indexSorter - Variable in class org.apache.arrow.algorithm.sort.VariableWidthOutOfPlaceVectorSorter
 
indexType() - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
The dictionary indices are constrained to be non-negative integers.
indexType(Int) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
indicesBuffer() - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
indicesBuffer stores the location and size of the array that contains the column indices of the corresponding non-zero values.
indicesBuffer(Buffer) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
indicesBuffer() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
The location and size of the indices matrix's data
indicesBuffer(Buffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
indicesBuffers(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
indicesBuffers stores values of nodes.
indicesBuffers(Buffer, int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indicesBuffersLength() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indicesBuffersVector() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indicesBuffersVector(Buffer.Vector) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indicesStrides(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
Non-negative byte offsets to advance one value cell along each dimension If omitted, default to row-major order (C-like).
indicesStridesAsByteBuffer() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
indicesStridesInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
indicesStridesLength() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
indicesStridesVector() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
indicesStridesVector(LongVector) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
indicesType() - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
The type of values in indicesBuffer
indicesType(Int) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
indicesType() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
The type of values in indicesBuffer
indicesType(Int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
indicesType() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
The type of values in indicesBuffers
indicesType(Int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indptrBuffer() - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
indptrBuffer stores the location and size of indptr array that represents the range of the rows.
indptrBuffer(Buffer) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
indptrBuffers(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
indptrBuffers stores the sparsity structure.
indptrBuffers(Buffer, int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indptrBuffersLength() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indptrBuffersVector() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indptrBuffersVector(Buffer.Vector) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
indptrType() - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
The type of values in indptrBuffer
indptrType(Int) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
indptrType() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
CSF is a generalization of compressed sparse row (CSR) index.
indptrType(Int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
INFO_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
INFO_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.PollInfo
 
INFO_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
INFO_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
INITIAL_VALUE_ALLOCATION - Static variable in class org.apache.arrow.vector.BaseValueVector
 
initialize() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
 
initialize() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Reads the schema and initializes the vectors.
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Initialize the children in schema for this Field.
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Initialize the children in schema for this Field.
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Initialize the children in schema for this Field.
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.ListVector
 
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.MapVector
Initialize child vectors of the map from the given list of fields.
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
Initializes the struct's members from the given Fields.
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.UnionVector
 
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
initializeChildrenFromFields(List<Field>) - Method in interface org.apache.arrow.vector.FieldVector
Initializes the child vectors to be later loaded with loadBuffers.
initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.NullVector
 
innerVectorIndex - Variable in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
 
InPlaceVectorSorter<V extends ValueVector> - Interface in org.apache.arrow.algorithm.sort
Basic interface for sorting a vector in-place.
insert(String, String) - Method in interface org.apache.arrow.flight.CallHeaders
Insert a metadata pair with the given value.
insert(String, byte[]) - Method in interface org.apache.arrow.flight.CallHeaders
Insert a metadata pair with the given value.
insert(String, String) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
insert(String, byte[]) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
insert(String, String) - Method in class org.apache.arrow.flight.FlightCallHeaders
 
insert(String, byte[]) - Method in class org.apache.arrow.flight.FlightCallHeaders
 
insert(String, String) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
insert(String, byte[]) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
INSTANCE - Static variable in class org.apache.arrow.compression.CommonsCompressionFactory
 
INSTANCE - Static variable in class org.apache.arrow.memory.util.hash.SimpleHasher
 
INSTANCE - Static variable in class org.apache.arrow.vector.complex.impl.NullReader
 
INSTANCE - Static variable in class org.apache.arrow.vector.compression.NoCompressionCodec.Factory
 
INSTANCE - Static variable in class org.apache.arrow.vector.compression.NoCompressionCodec
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
INSTANCE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
INSTANCE - Static variable in class org.apache.arrow.vector.ZeroVector
 
Int - Class in org.apache.arrow.flatbuf
 
Int() - Constructor for class org.apache.arrow.flatbuf.Int
 
Int - Static variable in class org.apache.arrow.flatbuf.Type
 
Int(int, boolean) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
Int.Vector - Class in org.apache.arrow.flatbuf
 
IntAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Int Arrow types.
IntAvaticaParameterConverter(ArrowType.Int) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.IntAvaticaParameterConverter
 
IntBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for 32-bit integers.
IntBinder(IntVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.IntBinder
 
IntBinder(IntVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.IntBinder
 
IntComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.IntComparator
 
IntConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume int type values from ResultSet.
IntConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.IntConsumer
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
integer() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
integer() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
integer() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
integer() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
integer() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
integer() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
integer() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
integer(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
integer(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Integration - Class in org.apache.arrow.tools
Application for cross language integration testing.
IntegrationProducer - Class in org.apache.arrow.flight.integration.tests
A FlightProducer that hosts an in memory store of Arrow buffers.
IntegrationProducer(BufferAllocator, Location) - Constructor for class org.apache.arrow.flight.integration.tests.IntegrationProducer
Constructs a new instance.
intercept(FlightClientMiddleware.Factory) - Method in class org.apache.arrow.flight.FlightClient.Builder
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.apache.arrow.flight.auth.ClientAuthInterceptor
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class org.apache.arrow.flight.auth.ServerAuthInterceptor
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.apache.arrow.flight.grpc.ClientInterceptorAdapter
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class org.apache.arrow.flight.grpc.ServerInterceptorAdapter
 
INTERNAL - Static variable in class org.apache.arrow.flight.CallStatus
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
 
internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
 
internalNioBuffer(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
interruptWait() - Method in class org.apache.arrow.flight.BackpressureStrategy.CallbackBackpressureStrategy
Interrupt waiting on the listener to change state.
Interval - Class in org.apache.arrow.flatbuf
 
Interval() - Constructor for class org.apache.arrow.flatbuf.Interval
 
Interval - Static variable in class org.apache.arrow.flatbuf.Type
 
Interval(IntervalUnit) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
Interval.Vector - Class in org.apache.arrow.flatbuf
 
IntervalAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Interval Arrow types.
IntervalAvaticaParameterConverter(ArrowType.Interval) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.IntervalAvaticaParameterConverter
 
intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
intervalDay() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
intervalDay() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
intervalDay(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
IntervalDayComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.IntervalDayComparator
 
IntervalDayHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
IntervalDayHolder() - Constructor for class org.apache.arrow.vector.holders.IntervalDayHolder
 
IntervalDayHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
IntervalDayHolderReaderImpl(IntervalDayHolder) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
IntervalDayReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
IntervalDayReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
IntervalDayReaderImpl(IntervalDayVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
IntervalDayVector - Class in org.apache.arrow.vector
IntervalDayVector implements a fixed width vector (8 bytes) of interval (days and milliseconds) values which could be null.
IntervalDayVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalDayVector
Instantiate a IntervalDayVector.
IntervalDayVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalDayVector
Instantiate a IntervalDayVector.
IntervalDayVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalDayVector
Instantiate a IntervalDayVector.
IntervalDayWriter - Interface in org.apache.arrow.vector.complex.writer
 
IntervalDayWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
IntervalDayWriterImpl(IntervalDayVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
intervalMonthDayNano() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
intervalMonthDayNano(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
IntervalMonthDayNanoHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
IntervalMonthDayNanoHolder() - Constructor for class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
 
IntervalMonthDayNanoHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
IntervalMonthDayNanoHolderReaderImpl(IntervalMonthDayNanoHolder) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
IntervalMonthDayNanoReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
IntervalMonthDayNanoReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
IntervalMonthDayNanoReaderImpl(IntervalMonthDayNanoVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
IntervalMonthDayNanoVector - Class in org.apache.arrow.vector
IntervalMonthDayNanoVector implements a fixed width vector (16 bytes) of interval (month, days and nanoseconds) values which could be null.
IntervalMonthDayNanoVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalMonthDayNanoVector
Instantiate a IntervalMonthDayNanoVector.
IntervalMonthDayNanoVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalMonthDayNanoVector
Instantiate a IntervalMonthDayNanoVector.
IntervalMonthDayNanoVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalMonthDayNanoVector
Instantiate a IntervalMonthDayNanoVector.
IntervalMonthDayNanoWriter - Interface in org.apache.arrow.vector.complex.writer
 
IntervalMonthDayNanoWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
IntervalMonthDayNanoWriterImpl(IntervalMonthDayNanoVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
IntervalStringUtils - Class in org.apache.arrow.driver.jdbc.utils
Utility class to format periods similar to Oracle's representation of "INTERVAL * to *" data type.
IntervalUnit - Class in org.apache.arrow.flatbuf
 
IntervalUnit - Enum in org.apache.arrow.vector.types
Resolutions for Interval Vectors.
intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
intervalYear() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
intervalYear() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
intervalYear(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
IntervalYearHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
IntervalYearHolder() - Constructor for class org.apache.arrow.vector.holders.IntervalYearHolder
 
IntervalYearHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
IntervalYearHolderReaderImpl(IntervalYearHolder) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
IntervalYearReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
IntervalYearReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
IntervalYearReaderImpl(IntervalYearVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
IntervalYearVector - Class in org.apache.arrow.vector
IntervalYearVector implements a fixed width (4 bytes) vector of interval (years and months) values which could be null.
IntervalYearVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalYearVector
Instantiate a IntervalYearVector.
IntervalYearVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalYearVector
Instantiate a IntervalYearVector.
IntervalYearVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntervalYearVector
Instantiate a IntervalYearVector.
IntervalYearWriter - Interface in org.apache.arrow.vector.complex.writer
 
IntervalYearWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
IntervalYearWriterImpl(IntervalYearVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
IntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
IntHolder() - Constructor for class org.apache.arrow.vector.holders.IntHolder
 
IntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
IntHolderReaderImpl(IntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
IntReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
IntReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
IntReaderImpl(IntVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
intToBytes(int, byte[]) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Convert an integer to a little endian 4 byte array.
IntVector - Class in org.apache.arrow.vector
IntVector implements a fixed width (4 bytes) vector of integer values which could be null.
IntVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntVector
Instantiate a IntVector.
IntVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntVector
Instantiate a IntVector.
IntVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.IntVector
Instantiate a IntVector.
IntWriter - Interface in org.apache.arrow.vector.complex.writer
 
IntWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
IntWriterImpl(IntVector) - Constructor for class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
INVALID_ARGUMENT - Static variable in class org.apache.arrow.flight.CallStatus
 
InvalidArrowFileException - Exception in org.apache.arrow.vector.ipc
Exception indicating a problem with an Arrow File (https://arrow.apache.org/docs/format/IPC.html#file-format).
InvalidArrowFileException(String) - Constructor for exception org.apache.arrow.vector.ipc.InvalidArrowFileException
 
invalidateReader() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
invalidateReader() - Method in class org.apache.arrow.vector.complex.ListVector
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
io.netty.buffer - package io.netty.buffer
 
ioBuffer() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
ioBuffer(int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
ioBuffer(int, int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
IPC_CONTINUATION_TOKEN - Static variable in class org.apache.arrow.vector.ipc.message.MessageSerializer
 
IpcOption - Class in org.apache.arrow.vector.ipc.message
IPC options, now only use for write.
IpcOption() - Constructor for class org.apache.arrow.vector.ipc.message.IpcOption
 
IpcOption(boolean, MetadataVersion) - Constructor for class org.apache.arrow.vector.ipc.message.IpcOption
 
isAllocationFailed() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
 
isAssertionsEnabled() - Static method in class org.apache.arrow.memory.util.AssertionUtil
 
isAutoIncrement(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets if the column is auto incremented.
isAutoIncrement() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns if the column is auto incremented.
isCancelled() - Method in class org.apache.arrow.flight.AsyncPutListener
 
isCancelled() - Method in interface org.apache.arrow.flight.FlightClient.PutListener
Check if the call has been cancelled.
isCancelled() - Method in interface org.apache.arrow.flight.FlightProducer.CallContext
Whether the call has been cancelled by the client.
isCancelled() - Method in interface org.apache.arrow.flight.FlightProducer.ServerStreamListener
Check whether the call has been cancelled.
isCancelled() - Method in class org.apache.arrow.flight.SyncPutListener
 
isCanonical() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
This flag is true if and only if the indices matrix is sorted in row-major order, and does not have duplicated entries.
isCaseSensitive(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets if the column is case-sensitive.
isCaseSensitive() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns if the column is case-sensitive.
isCatalogAtStart() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
isClosed() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
isClosed() - Method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Gets whether this queue is closed.
isClosed() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Returns if the prepared statement is already closed.
isClosed() - Method in interface org.apache.arrow.memory.AllocationReservation
Return whether or not the reservation has been closed.
isCommand() - Method in class org.apache.arrow.flight.FlightDescriptor
 
isComplex() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexType
 
isComplex() - Method in class org.apache.arrow.vector.types.pojo.ArrowType
 
isComplex() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveType
 
isCreated() - Method in class org.apache.arrow.vector.AddOrGetResult
Returns whether the vector is created.
isDelta() - Method in class org.apache.arrow.flatbuf.DictionaryBatch
If isDelta is true the values in the dictionary are to be appended to a dictionary with the indicated id.
isDelta() - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
isDirect() - Method in class io.netty.buffer.NettyArrowBuf
 
isDirectBufferPooled() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
isEmpty() - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Returns whether this Map has no elements.
isEmpty(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Return if value at index is empty (this implementation is always false).
isEmpty(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
Check if element at given index is empty list.
isEmpty(int) - Method in class org.apache.arrow.vector.complex.ListVector
Check if element at given index is empty list.
isEmpty() - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
isEmpty() - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
isEmpty() - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
 
isEmpty() - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
isEmptyStruct() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
isEmptyStruct() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
isEmptyStruct() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
isEmptyStruct() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
Whether this writer is a struct writer and is empty (has no children).
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
isInitialized() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
isInitialized() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
isListWriter() - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
isListWriter() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
isMac() - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Check if the operating system running the software is Mac.
isNull(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcListVectorAccessor
 
isNull(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcFixedSizeListVectorAccessor
 
isNull(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcLargeListVectorAccessor
 
isNull(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcListVectorAccessor
 
isNull(int) - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.ArrowFlightJdbcMapVectorAccessor
 
isNull(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Check if element at given index is null.
isNull(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Check if element at given index is null.
isNull(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Check if element at given index is null.
isNull(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Return if value at index is null (this implementation is always false).
isNull(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
IMPORTANT: Union types always return non null as there is no validity buffer.
isNull(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Returns whether the value at index null.
isNull(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
Check if element at given index is null.
isNull(int) - Method in class org.apache.arrow.vector.complex.ListVector
Check if element at given index is null.
isNull(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
isNull(int) - Method in class org.apache.arrow.vector.complex.StructVector
Returns true if the value at the provided index is null.
isNull(int) - Method in class org.apache.arrow.vector.complex.UnionVector
IMPORTANT: Union types always return non null as there is no validity buffer.
isNull(int) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
isNull(int) - Method in class org.apache.arrow.vector.NullVector
 
isNull(String) - Method in class org.apache.arrow.vector.table.Row
For vectors other than Union and DenseUnion, returns true if the value at columnName is null, and false otherwise.
isNull(int) - Method in class org.apache.arrow.vector.table.Row
For vectors other than Union and DenseUnion, returns true if the value at columnIndex is null, and false otherwise.
isNull(int) - Method in interface org.apache.arrow.vector.ValueVector
Check whether an element in the vector is null.
isNull(int) - Method in class org.apache.arrow.vector.ZeroVector
 
isNullable() - Method in class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
The nullability.
isNullable() - Method in class org.apache.arrow.vector.types.pojo.Field
 
isNullable() - Method in class org.apache.arrow.vector.types.pojo.FieldType
 
isOk() - Method in class org.apache.arrow.memory.AllocationOutcome
Returns true if the allocation was a success.
isOk() - Method in enum org.apache.arrow.memory.AllocationOutcome.Status
 
isOpen() - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
isOrdered() - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
By default, dictionaries are not ordered, or the order does not have semantic meaning.
isOrdered() - Method in class org.apache.arrow.vector.types.pojo.DictionaryEncoding
 
isOverLimit() - Method in interface org.apache.arrow.memory.BufferAllocator
Return whether or not this allocator (or one if its parents) is over its limits.
isReadOnly() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
isReadOnly() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
isReadOnly(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets if the column is read only.
isReadOnly() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns if the column is read only.
isReady() - Method in interface org.apache.arrow.flight.OutboundStreamListener
A hint indicating whether the client is ready to receive data without excessive buffering.
isReuseVectorSchemaRoot() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Get whether it is allowed to reuse the vector schema root.
isRowDeleted(int) - Method in class org.apache.arrow.vector.table.BaseTable
Returns true if the row at the given index has been deleted and false otherwise.
isSafe(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Check if the given index is within the current value capacity of the vector.
isSafe(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Check if the given index is within the current value capacity of the vector.
isSafe(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Check if the given index is within the current value capacity of the vector.
isSearchable(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets if the column is searchable.
isSearchable() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
Returns if the column is searchable.
isSet(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
isSet(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
isSet(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
isSet(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
isSet(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Returns non-zero when the value at index is non-null.
isSet() - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
isSet() - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
isSet(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
isSet(int) - Method in class org.apache.arrow.vector.complex.ListVector
isSet() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.BitReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.IntReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
 
isSet() - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
 
isSet(int) - Method in class org.apache.arrow.vector.complex.StructVector
Returns true the value at the given index is set (i.e.
isSet(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
isSet - Variable in class org.apache.arrow.vector.holders.BigIntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.BitHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.ComplexHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.DateDayHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.DateMilliHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.Decimal256Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.DecimalHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.DenseUnionHolder
 
isSet() - Method in class org.apache.arrow.vector.holders.DenseUnionHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.DurationHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.Float4Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.Float8Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.IntervalDayHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.IntervalYearHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.IntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.LargeVarBinaryHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.LargeVarCharHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableBigIntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableBitHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableDateDayHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableDateMilliHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableDecimal256Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableDecimalHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableDurationHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableFloat4Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableFloat8Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableIntervalDayHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableIntervalYearHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableIntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableSmallIntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeMicroHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeMilliHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeNanoHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeSecHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMicroHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMicroTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMilliHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMilliTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampNanoHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampNanoTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampSecHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTimeStampSecTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableTinyIntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableUInt1Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableUInt2Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableUInt4Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableUInt8Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableVarBinaryHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.NullableVarCharHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.SmallIntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeMicroHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeMilliHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeNanoHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeSecHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampMicroHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampMicroTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampMilliHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampMilliTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampNanoHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampNanoTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampSecHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TimeStampSecTZHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.TinyIntHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.UInt1Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.UInt2Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.UInt4Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.UInt8Holder
 
isSet - Variable in class org.apache.arrow.vector.holders.UnionHolder
 
isSet() - Method in class org.apache.arrow.vector.holders.UnionHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.VarBinaryHolder
 
isSet - Variable in class org.apache.arrow.vector.holders.VarCharHolder
 
isShutdown() - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
isSigned() - Method in class org.apache.arrow.flatbuf.Int
 
isStructWriter() - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
isStructWriter() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
isTerminated() - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
isUsed() - Method in interface org.apache.arrow.memory.AllocationReservation
Return whether or not the reservation has been used.
isValid(int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
isValid(byte[]) - Method in interface org.apache.arrow.flight.auth.BasicServerAuthHandler.BasicAuthValidator
 
isValid(byte[]) - Method in class org.apache.arrow.flight.auth.BasicServerAuthHandler
 
isValid(byte[]) - Method in interface org.apache.arrow.flight.auth.ServerAuthHandler
Deprecated.
Validate the client token provided on each call.
isWindows() - Static method in class org.apache.arrow.driver.jdbc.client.utils.ClientAuthenticationUtils
Check if the operating system running the software is Windows.
isWrapperFor(Class<?>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
isWrapperFor(Class<?>) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
iter(AutoCloseable...) - Static method in class org.apache.arrow.util.AutoCloseables
Converts ac to a Iterable filtering out any null values.
iterator() - Method in class org.apache.arrow.vector.BaseValueVector
 
iterator() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
iterator() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
iterator() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
iterator() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
iterator() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
iterator() - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
iterator() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
iterator() - Method in class org.apache.arrow.vector.complex.UnionVector
 
iterator() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
iterator() - Method in class org.apache.arrow.vector.NullVector
 
iterator() - Method in class org.apache.arrow.vector.table.Table
Returns a Row iterator for this Table.

J

JdbcConsumer<T extends ValueVector> - Interface in org.apache.arrow.adapter.jdbc.consumer
An abstraction that is used to consume values from ResultSet.
JdbcConsumerException - Exception in org.apache.arrow.adapter.jdbc.consumer.exceptions
Exception while consuming JDBC data.
JdbcConsumerException(String, Throwable, JdbcFieldInfo, ArrowType) - Constructor for exception org.apache.arrow.adapter.jdbc.consumer.exceptions.JdbcConsumerException
Construct JdbcConsumerException with all fields.
JdbcFieldInfo - Class in org.apache.arrow.adapter.jdbc
This class represents the information about a JDBC ResultSet Field that is needed to construct an ArrowType.
JdbcFieldInfo(int) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
Builds a JdbcFieldInfo using only the Types type.
JdbcFieldInfo(int, int, int) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
Builds a JdbcFieldInfo from the Types type, precision, and scale.
JdbcFieldInfo(int, int, int, int) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
Builds a JdbcFieldInfo from the Types type, nullability, precision, and scale.
JdbcFieldInfo(ResultSetMetaData, int) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
Builds a JdbcFieldInfo from the corresponding ResultSetMetaData column.
JdbcFieldInfo(ResultSet) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
Builds a JdbcFieldInfo from the corresponding row from a DatabaseMetaData.getColumns(java.lang.String, java.lang.String, java.lang.String, java.lang.String) ResultSet.
JdbcParameterBinder - Class in org.apache.arrow.adapter.jdbc
A binder binds JDBC prepared statement parameters to rows of Arrow data from a VectorSchemaRoot.
JdbcParameterBinder.Builder - Class in org.apache.arrow.adapter.jdbc
A builder for a JdbcParameterBinder.
JdbcToArrow - Class in org.apache.arrow.adapter.jdbc
Utility class to convert JDBC objects to columnar Arrow format objects.
JdbcToArrow() - Constructor for class org.apache.arrow.adapter.jdbc.JdbcToArrow
 
JdbcToArrowConfig - Class in org.apache.arrow.adapter.jdbc
This class configures the JDBC-to-Arrow conversion process.
JdbcToArrowConfig.JdbcConsumerFactory - Interface in org.apache.arrow.adapter.jdbc
Interface for a function that gets a JDBC consumer for the given values.
JdbcToArrowConfigBuilder - Class in org.apache.arrow.adapter.jdbc
This class builds JdbcToArrowConfigs.
JdbcToArrowConfigBuilder() - Constructor for class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Default constructor for the JdbcToArrowConfigBuilder}.
JdbcToArrowConfigBuilder(BufferAllocator, Calendar) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Constructor for the JdbcToArrowConfigBuilder.
JdbcToArrowConfigBuilder(BufferAllocator, Calendar, boolean) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Constructor for the JdbcToArrowConfigBuilder.
jdbcToArrowSchema(ResultSetMetaData, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Create Arrow Schema object for the given JDBC ResultSetMetaData.
jdbcToArrowSchema(ParameterMetaData, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Create Arrow Schema object for the given JDBC ResultSetMetaData.
jdbcToArrowSchema(ResultSetMetaData, JdbcToArrowConfig) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Create Arrow Schema object for the given JDBC ResultSetMetaData.
JdbcToArrowUtils - Class in org.apache.arrow.adapter.jdbc
Class that does most of the work to convert JDBC ResultSet data into Arrow columnar format Vector objects.
JdbcToArrowUtils() - Constructor for class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
 
jdbcToArrowVectors(ResultSet, VectorSchemaRoot, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Iterate the given JDBC ResultSet object to fetch the data and transpose it to populate the given Arrow Vector objects.
jdbcToArrowVectors(ResultSet, VectorSchemaRoot, JdbcToArrowConfig) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
Iterate the given JDBC ResultSet object to fetch the data and transpose it to populate the given Arrow Vector objects.
jdbcType - Variable in class org.apache.arrow.adapter.jdbc.binder.BaseColumnBinder
 
JsonFileReader - Class in org.apache.arrow.vector.ipc
A reader for JSON files that translates them into vectors.
JsonFileReader(File, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.JsonFileReader
Constructs a new instance.
JsonFileWriter - Class in org.apache.arrow.vector.ipc
A writer that converts binary Vectors into an internal, unstable JSON format suitable for integration testing.
JsonFileWriter(File) - Constructor for class org.apache.arrow.vector.ipc.JsonFileWriter
Constructs a new writer that will output to outputFile.
JsonFileWriter(File, JsonFileWriter.JSONWriteConfig) - Constructor for class org.apache.arrow.vector.ipc.JsonFileWriter
Constructs a new writer that will output to outputFile with the given options.
JsonFileWriter.JSONWriteConfig - Class in org.apache.arrow.vector.ipc
Configuration POJO for writing JSON files.
JsonStringArrayList<E> - Class in org.apache.arrow.vector.util
Extension of ArrayList that JsonStringArrayList.toString() method returns the serialized JSON version of its members (or throws an exception if they can't be converted to JSON).
JsonStringArrayList() - Constructor for class org.apache.arrow.vector.util.JsonStringArrayList
 
JsonStringArrayList(int) - Constructor for class org.apache.arrow.vector.util.JsonStringArrayList
 
JsonStringHashMap<K,V> - Class in org.apache.arrow.vector.util
Simple class that extends the regular java.util.HashMap but overrides the toString() method of the HashMap class to produce a JSON string instead
JsonStringHashMap() - Constructor for class org.apache.arrow.vector.util.JsonStringHashMap
 

K

key() - Method in class org.apache.arrow.flatbuf.KeyValue
 
key() - Method in class org.apache.arrow.vector.complex.impl.UnionMapReader
Start reading a key from the map entry.
key() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
Return the key writer that is used to write to the "key" field.
key() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
key() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.MapWriter
 
KEY_NAME - Static variable in class org.apache.arrow.vector.complex.MapVector
 
keyAsByteBuffer() - Method in class org.apache.arrow.flatbuf.KeyValue
 
KeyFactory(FlightServerMiddleware.Key<T>, FlightServerMiddleware.Factory<T>) - Constructor for class org.apache.arrow.flight.grpc.ServerInterceptorAdapter.KeyFactory
 
keyInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.KeyValue
 
keys() - Method in interface org.apache.arrow.flight.CallHeaders
Get a set of all the metadata keys.
keys() - Method in class org.apache.arrow.flight.ErrorFlightMetadata
 
keys() - Method in class org.apache.arrow.flight.FlightCallHeaders
 
keys() - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
keys() - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
keys() - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
keys() - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
 
keys() - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
keySet() - Method in class org.apache.arrow.flight.grpc.RequestContextAdapter
 
keySet() - Method in interface org.apache.arrow.flight.RequestContext
Retrieves the keys that have been registered to this context.
keysSorted() - Method in class org.apache.arrow.flatbuf.Map
Set to true if the keys within each value are sorted
KeyValue - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- user defined key value pairs to add custom metadata to arrow key namespacing is the responsibility of the user
KeyValue() - Constructor for class org.apache.arrow.flatbuf.KeyValue
 
KeyValue.Vector - Class in org.apache.arrow.flatbuf
 

L

LargeBinary - Class in org.apache.arrow.flatbuf
Same as Binary, but with 64-bit offsets, allowing to represent extremely large data values.
LargeBinary() - Constructor for class org.apache.arrow.flatbuf.LargeBinary
 
LargeBinary - Static variable in class org.apache.arrow.flatbuf.Type
 
LargeBinary() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
LargeBinary.Vector - Class in org.apache.arrow.flatbuf
 
LargeBinaryAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for LargeBinary Arrow types.
LargeBinaryAvaticaParameterConverter(ArrowType.LargeBinary) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.LargeBinaryAvaticaParameterConverter
 
LargeBuffer - Class in io.netty.buffer
A MutableWrappedByteBuf that also maintains a metric of the number of huge buffer bytes and counts.
LargeBuffer(ByteBuf) - Constructor for class io.netty.buffer.LargeBuffer
 
LargeList - Class in org.apache.arrow.flatbuf
Same as List, but with 64-bit offsets, allowing to represent extremely large data values.
LargeList() - Constructor for class org.apache.arrow.flatbuf.LargeList
 
LargeList - Static variable in class org.apache.arrow.flatbuf.Type
 
LargeList() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
LargeList.Vector - Class in org.apache.arrow.flatbuf
 
LargeListAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for LargeList Arrow types.
LargeListAvaticaParameterConverter(ArrowType.LargeList) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.LargeListAvaticaParameterConverter
 
LargeListVector - Class in org.apache.arrow.vector.complex
A list vector contains lists of a specific type of elements.
LargeListVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.LargeListVector
Constructs a new instance.
LargeListVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.LargeListVector
Creates a new instance.
LargeListView - Class in org.apache.arrow.flatbuf
Same as ListView, but with 64-bit offsets and sizes, allowing to represent extremely large data values.
LargeListView() - Constructor for class org.apache.arrow.flatbuf.LargeListView
 
LargeListView - Static variable in class org.apache.arrow.flatbuf.Type
 
LargeListView.Vector - Class in org.apache.arrow.flatbuf
 
LargeMemoryUtil - Class in org.apache.arrow.memory.util
Contains utilities for dealing with a 64-bit address base.
largeOffsetBuffer() - Static method in class org.apache.arrow.vector.BufferLayout
 
LargeUtf8 - Class in org.apache.arrow.flatbuf
Same as Utf8, but with 64-bit offsets, allowing to represent extremely large data values.
LargeUtf8() - Constructor for class org.apache.arrow.flatbuf.LargeUtf8
 
LargeUtf8 - Static variable in class org.apache.arrow.flatbuf.Type
 
LargeUtf8() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
LargeUtf8.Vector - Class in org.apache.arrow.flatbuf
 
LargeUtf8AvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for LargeUtf8 Arrow types.
LargeUtf8AvaticaParameterConverter(ArrowType.LargeUtf8) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.LargeUtf8AvaticaParameterConverter
 
largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
largeVarBinary() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
largeVarBinary(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
LargeVarBinaryHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
LargeVarBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.LargeVarBinaryHolder
 
LargeVarBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
LargeVarBinaryHolderReaderImpl(LargeVarBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
LargeVarBinaryReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
LargeVarBinaryReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
LargeVarBinaryReaderImpl(LargeVarBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
LargeVarBinaryVector - Class in org.apache.arrow.vector
LargeVarBinaryVector implements a large variable width vector of binary values which could be NULL.
LargeVarBinaryVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.LargeVarBinaryVector
Instantiate a LargeVarBinaryVector.
LargeVarBinaryVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.LargeVarBinaryVector
Instantiate a LargeVarBinaryVector.
LargeVarBinaryVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.LargeVarBinaryVector
Instantiate a LargeVarBinaryVector.
LargeVarBinaryWriter - Interface in org.apache.arrow.vector.complex.writer
 
LargeVarBinaryWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
LargeVarBinaryWriterImpl(LargeVarBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
largeVarChar() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
largeVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
LargeVarCharHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
LargeVarCharHolder() - Constructor for class org.apache.arrow.vector.holders.LargeVarCharHolder
 
LargeVarCharHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
LargeVarCharHolderReaderImpl(LargeVarCharHolder) - Constructor for class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
LargeVarCharReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
LargeVarCharReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
LargeVarCharReaderImpl(LargeVarCharVector) - Constructor for class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
LargeVarCharVector - Class in org.apache.arrow.vector
LargeVarCharVector implements a variable width vector of VARCHAR values which could be NULL.
LargeVarCharVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.LargeVarCharVector
Instantiate a LargeVarCharVector.
LargeVarCharVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.LargeVarCharVector
Instantiate a LargeVarCharVector.
LargeVarCharVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.LargeVarCharVector
Instantiate a LargeVarCharVector.
LargeVarCharWriter - Interface in org.apache.arrow.vector.complex.writer
 
LargeVarCharWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
LargeVarCharWriterImpl(LargeVarCharVector) - Constructor for class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
lastSet - Variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
lastSet - Variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
lastSet - Variable in class org.apache.arrow.vector.complex.ListVector
The maximum index that is actually set.
lastValueCapacity - Variable in class org.apache.arrow.vector.BaseFixedWidthVector
 
length() - Method in class org.apache.arrow.flatbuf.Buffer
The absolute length (in bytes) of the memory buffer.
length() - Method in class org.apache.arrow.flatbuf.FieldNode
The number of value slots in the Arrow array at this level of a nested tree
length() - Method in class org.apache.arrow.flatbuf.RecordBatch
number of records / rows.
length - Variable in class org.apache.arrow.vector.util.ReusableByteArray
 
LinearDictionaryEncoder<E extends BaseIntVector,D extends ValueVector> - Class in org.apache.arrow.algorithm.dictionary
Dictionary encoder based on linear search.
LinearDictionaryEncoder(D) - Constructor for class org.apache.arrow.algorithm.dictionary.LinearDictionaryEncoder
Constructs a dictionary encoder, with the encode null flag set to false.
LinearDictionaryEncoder(D, boolean) - Constructor for class org.apache.arrow.algorithm.dictionary.LinearDictionaryEncoder
Constructs a dictionary encoder.
linearSearch(V, VectorValueComparator<V>, V, int) - Static method in class org.apache.arrow.algorithm.search.VectorSearcher
Search for a particular element from the key vector in the target vector by traversing the vector in sequence.
List - Class in org.apache.arrow.flatbuf
 
List() - Constructor for class org.apache.arrow.flatbuf.List
 
List - Static variable in class org.apache.arrow.flatbuf.Type
 
list() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
list() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
list - Variable in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
list() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
list() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
list() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
list() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
list() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
list() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
list(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
list(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
List() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.List
 
List.Vector - Class in org.apache.arrow.flatbuf
 
listActions(CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Lists actions available on the Flight service.
listActions(FlightProducer.CallContext, FlightProducer.StreamListener<ActionType>) - Method in interface org.apache.arrow.flight.FlightProducer
List available application-defined RPCs.
listActions(Flight.Empty, StreamObserver<Flight.ActionType>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
A flight service exposes all of the available action types that it has along with descriptions.
listActions(Flight.Empty) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
A flight service exposes all of the available action types that it has along with descriptions.
listActions(Flight.Empty, StreamObserver<Flight.ActionType>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
A flight service exposes all of the available action types that it has along with descriptions.
listActions(FlightProducer.CallContext, FlightProducer.StreamListener<ActionType>) - Method in class org.apache.arrow.flight.NoOpFlightProducer
 
listActions(FlightProducer.CallContext, FlightProducer.StreamListener<ActionType>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Lists all available Flight SQL actions.
ListAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for List Arrow types.
ListAvaticaParameterConverter(ArrowType.List) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.ListAvaticaParameterConverter
 
ListBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for list of primitive values.
ListBinder(ListVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.ListBinder
 
ListBinder(ListVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.ListBinder
Init ListBinder and determine type of data vector.
listFlights(Criteria, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Get a list of available flights.
listFlights(FlightProducer.CallContext, Criteria, FlightProducer.StreamListener<FlightInfo>) - Method in interface org.apache.arrow.flight.FlightProducer
List available data streams on this service.
listFlights(Flight.Criteria, StreamObserver<Flight.FlightInfo>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
Get a list of available streams given a particular criteria.
listFlights(Flight.Criteria) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
Get a list of available streams given a particular criteria.
listFlights(Flight.Criteria, StreamObserver<Flight.FlightInfo>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
Get a list of available streams given a particular criteria.
listFlights(FlightProducer.CallContext, Criteria, FlightProducer.StreamListener<FlightInfo>) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenarioProducer
 
listFlights(FlightProducer.CallContext, Criteria, FlightProducer.StreamListener<FlightInfo>) - Method in class org.apache.arrow.flight.NoOpFlightProducer
 
listFlights(FlightProducer.CallContext, Criteria, FlightProducer.StreamListener<FlightInfo>) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
listOfStruct(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
Creates a new writer for a list of structs.
listOfStruct(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
listoftstruct(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
Deprecated.
use #listOfStruct() instead.
listoftstruct(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
Deprecated.
use #listOfStruct() instead.
listSize() - Method in class org.apache.arrow.flatbuf.FixedSizeList
Number of list items per value
ListSubfieldEncoder - Class in org.apache.arrow.vector.dictionary
Sub fields encoder/decoder for Dictionary encoded BaseListVector.
ListSubfieldEncoder(Dictionary, BufferAllocator) - Constructor for class org.apache.arrow.vector.dictionary.ListSubfieldEncoder
 
ListSubfieldEncoder(Dictionary, BufferAllocator, ArrowBufHasher) - Constructor for class org.apache.arrow.vector.dictionary.ListSubfieldEncoder
Construct an instance.
ListVector - Class in org.apache.arrow.vector.complex
A list vector contains lists of a specific type of elements.
ListVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.ListVector
Constructs a new instance.
ListVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.ListVector
Constructs a new instance.
ListView - Class in org.apache.arrow.flatbuf
Represents the same logical types that List can, but contains offsets and sizes allowing for writes in any order and sharing of child values among list values.
ListView() - Constructor for class org.apache.arrow.flatbuf.ListView
 
ListView - Static variable in class org.apache.arrow.flatbuf.Type
 
ListView.Vector - Class in org.apache.arrow.flatbuf
 
Little - Static variable in class org.apache.arrow.flatbuf.Endianness
 
LITTLE_ENDIAN - Static variable in class org.apache.arrow.memory.util.MemoryUtil
If the native byte order is little-endian.
load(ArrowFieldNode, ArrowBuf) - Method in interface org.apache.arrow.vector.BufferBacked
 
load(ArrowRecordBatch) - Method in class org.apache.arrow.vector.VectorLoader
Loads the record batch in the vectors.
loadDictionary(ArrowDictionaryBatch) - Method in class org.apache.arrow.vector.ipc.ArrowReader
Load an ArrowDictionaryBatch to the readers dictionary vectors.
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Load the buffers of this vector with provided source buffers.
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Load the buffers of this vector with provided source buffers.
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Load the buffers of this vector with provided source buffers.
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.complex.LargeListVector
Load the buffers of this vector with provided source buffers.
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.complex.ListVector
Load the buffers of this vector with provided source buffers.
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.complex.StructVector
 
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.complex.UnionVector
 
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in interface org.apache.arrow.vector.FieldVector
Loads data in the vectors.
loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.NullVector
 
loadNextBatch() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
Returns true if a batch was read, false if no more batches.
loadNextBatch() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Load the next ArrowRecordBatch to the vector schema root if available.
loadNextBatch() - Method in class org.apache.arrow.vector.ipc.ArrowStreamReader
Load the next ArrowRecordBatch to the vector schema root if available.
loadRecordBatch(ArrowBlock) - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
Loads record batch for the given block.
loadRecordBatch(ArrowRecordBatch) - Method in class org.apache.arrow.vector.ipc.ArrowReader
Load an ArrowRecordBatch to the readers VectorSchemaRoot.
loadValidityBuffer(ArrowFieldNode, ArrowBuf, BufferAllocator) - Static method in class org.apache.arrow.vector.BitVectorHelper
Returns a new buffer if the source validity buffer is either all null or all not-null, otherwise returns a buffer pointing to the same memory as source.
location(Location) - Method in class org.apache.arrow.flight.FlightClient.Builder
 
location(Location) - Method in class org.apache.arrow.flight.FlightServer.Builder
 
Location - Class in org.apache.arrow.flight
A URI where a Flight stream is available.
Location(String) - Constructor for class org.apache.arrow.flight.Location
Constructs a new instance.
Location(URI) - Constructor for class org.apache.arrow.flight.Location
Construct a new instance from an existing URI.
LOCATION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
LocationSchemes - Class in org.apache.arrow.flight
Constants representing well-known URI schemes for Flight services.
locatorsUpdateCopy() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
LOGGER - Static variable in class org.apache.arrow.vector.ipc.ArrowWriter
 
logHistory(Logger) - Method in class org.apache.arrow.memory.util.HistoricalLog
Write the history of this object to the given Logger.
LongComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.LongComparator
 
longToBytes(long, byte[]) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Convert a long to a little-endian 8 byte array.
lookup(long) - Method in interface org.apache.arrow.vector.dictionary.DictionaryProvider
Return the dictionary for the given ID.
lookup(long) - Method in class org.apache.arrow.vector.dictionary.DictionaryProvider.MapDictionaryProvider
 
lookup(long) - Method in class org.apache.arrow.vector.ipc.ArrowReader
Lookup a dictionary that has been loaded using the dictionary id.
lookup(long) - Method in class org.apache.arrow.vector.ipc.JsonFileReader
 
lookup(String) - Static method in class org.apache.arrow.vector.types.pojo.ExtensionTypeRegistry
 
LowCostIdentityHashMap<K,V extends ValueWithKeyIncluded<K>> - Class in org.apache.arrow.memory
Highly specialized IdentityHashMap that implements only partial Map APIs.
LowCostIdentityHashMap() - Constructor for class org.apache.arrow.memory.LowCostIdentityHashMap
Creates a Map with default expected maximum size.
LowCostIdentityHashMap(int) - Constructor for class org.apache.arrow.memory.LowCostIdentityHashMap
Creates a Map with the specified maximum size parameter.
LZ4_FRAME - Static variable in class org.apache.arrow.flatbuf.CompressionType
 
Lz4CompressionCodec - Class in org.apache.arrow.compression
Compression codec for the LZ4 algorithm.
Lz4CompressionCodec() - Constructor for class org.apache.arrow.compression.Lz4CompressionCodec
 

M

main(String[]) - Static method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
 
main(String[]) - Static method in class org.apache.arrow.tools.EchoServer
Main method to run the server, the first argument is an optional port number.
main(String[]) - Static method in class org.apache.arrow.tools.FileRoundtrip
 
main(String[]) - Static method in class org.apache.arrow.tools.FileToStream
Main method.
main(String[]) - Static method in class org.apache.arrow.tools.Integration
Main method.
main(String[]) - Static method in class org.apache.arrow.tools.StreamToFile
Main method.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.BigIntVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.BitVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.ListVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.MapVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.StructVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.UnionVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.DateDayVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.DateMilliVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.Decimal256Vector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.DecimalVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.DurationVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.Float4Vector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.Float8Vector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.IntervalDayVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.IntervalYearVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.IntVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.LargeVarCharVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.NullVector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.SmallIntVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeMicroVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeMilliVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeNanoVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeSecVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TimeStampSecVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.TinyIntVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.UInt1Vector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.UInt2Vector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.UInt4Vector
 
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.UInt8Vector
 
makeTransferPair(ValueVector) - Method in interface org.apache.arrow.vector.ValueVector
Makes a new transfer pair used to transfer underlying buffers.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.VarBinaryVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.VarCharVector
Construct a TransferPair with a desired target vector of the same type.
makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.ZeroVector
 
Map - Class in org.apache.arrow.flatbuf
A Map is a logical nested type that is represented as List> In this layout, the keys and values are each respectively contiguous.
Map() - Constructor for class org.apache.arrow.flatbuf.Map
 
Map - Static variable in class org.apache.arrow.flatbuf.Type
 
map() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
map(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
map(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
map(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
map() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
map() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
map() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
map() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
map() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
map(boolean) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
map(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
map(String, boolean) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Map(boolean) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
Map.Vector - Class in org.apache.arrow.flatbuf
 
MapAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Map Arrow types.
MapAvaticaParameterConverter(ArrowType.Map) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.MapAvaticaParameterConverter
 
MapBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for map of primitive values.
MapBinder(MapVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.MapBinder
 
MapBinder(MapVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.MapBinder
Init MapBinder and determine type of data vector.
MapConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume map type values from ResultSet.
MapConsumer(MapVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.MapConsumer
Instantiate a MapConsumer.
MapDictionaryProvider(Dictionary...) - Constructor for class org.apache.arrow.vector.dictionary.DictionaryProvider.MapDictionaryProvider
Constructs a new instance from the given dictionaries.
MapVector - Class in org.apache.arrow.vector.complex
A MapVector is used to store entries of key/value pairs.
MapVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.MapVector
Construct a MapVector instance.
MapVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.MapVector
 
MapWithOrdinal<K,V> - Interface in org.apache.arrow.vector.util
An implementation of a map that supports constant time look-up by a generic key or an ordinal.
MapWithOrdinalImpl<K,V> - Class in org.apache.arrow.vector.util
An implementation of map that supports constant time look-up by a generic key or an ordinal.
MapWithOrdinalImpl() - Constructor for class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
MAX_ALLOCATION_SIZE - Static variable in class org.apache.arrow.vector.BaseValueVector
 
MAX_ALLOCATION_SIZE_PROPERTY - Static variable in class org.apache.arrow.vector.BaseValueVector
 
MAX_PRECISION - Static variable in class org.apache.arrow.vector.Decimal256Vector
 
MAX_PRECISION - Static variable in class org.apache.arrow.vector.DecimalVector
 
MAX_UINT1 - Static variable in class org.apache.arrow.vector.UInt1Vector
The maximum 8-bit unsigned integer.
MAX_UINT2 - Static variable in class org.apache.arrow.vector.UInt2Vector
The maximum 16-bit unsigned integer.
MAX_UINT4 - Static variable in class org.apache.arrow.vector.UInt4Vector
The maximum 32-bit unsigned integer.
MAX_UINT8 - Static variable in class org.apache.arrow.vector.UInt8Vector
The maximum 64-bit unsigned long integer.
maxInboundMessageSize(int) - Method in class org.apache.arrow.flight.FlightClient.Builder
Set the maximum inbound message size.
maxInboundMessageSize(int) - Method in class org.apache.arrow.flight.FlightServer.Builder
Set the maximum size of a message.
memoryAddress() - Method in class io.netty.buffer.NettyArrowBuf
 
memoryAddress() - Method in class org.apache.arrow.memory.AllocationManager
Return the absolute memory address pointing to the fist byte of underlying memory chunk.
memoryAddress() - Method in class org.apache.arrow.memory.ArrowBuf
 
memoryAddress() - Method in class org.apache.arrow.memory.ForeignAllocation
Get the address of this allocation.
memoryAddress() - Method in class org.apache.arrow.memory.NettyAllocationManager
 
memoryAddress() - Method in class org.apache.arrow.memory.UnsafeAllocationManager
 
MemoryUtil - Class in org.apache.arrow.memory.util
Utilities for memory related operations.
mergeDefinition(PerfOuterClass.Perf) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
mergeEndpoint(Flight.FlightEndpoint) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
mergeExpirationTime(Timestamp) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
mergeExpirationTime(Timestamp) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
mergeFlightDescriptor(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
mergeFlightDescriptor(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
mergeFlightDescriptor(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
mergeFrom(Flight.Action) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
mergeFrom(Flight.ActionType) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
mergeFrom(Flight.BasicAuth) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
mergeFrom(Flight.CancelFlightInfoRequest) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
mergeFrom(Flight.CancelFlightInfoResult) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
mergeFrom(Flight.Criteria) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
mergeFrom(Flight.Empty) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
mergeFrom(Flight.FlightData) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
mergeFrom(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
mergeFrom(Flight.FlightEndpoint) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
mergeFrom(Flight.FlightInfo) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
mergeFrom(Flight.HandshakeRequest) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
mergeFrom(Flight.HandshakeResponse) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
mergeFrom(Flight.Location) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
mergeFrom(Flight.PollInfo) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
mergeFrom(Flight.PutResult) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
mergeFrom(Flight.RenewFlightEndpointRequest) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
mergeFrom(Flight.Result) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
mergeFrom(Flight.SchemaResult) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
mergeFrom(Flight.Ticket) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
mergeFrom(PerfOuterClass.Perf) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
mergeFrom(PerfOuterClass.Token) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
mergeFrom(FlightSql.ActionBeginSavepointRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
mergeFrom(FlightSql.ActionBeginSavepointResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
mergeFrom(FlightSql.ActionBeginTransactionRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
mergeFrom(FlightSql.ActionBeginTransactionResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
mergeFrom(FlightSql.ActionCancelQueryRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
mergeFrom(FlightSql.ActionCancelQueryResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
mergeFrom(FlightSql.ActionClosePreparedStatementRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
mergeFrom(FlightSql.ActionCreatePreparedStatementRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
mergeFrom(FlightSql.ActionCreatePreparedStatementResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
mergeFrom(FlightSql.ActionCreatePreparedSubstraitPlanRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
mergeFrom(FlightSql.ActionEndSavepointRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
mergeFrom(FlightSql.ActionEndTransactionRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
mergeFrom(FlightSql.CommandGetCatalogs) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
mergeFrom(FlightSql.CommandGetCrossReference) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
mergeFrom(FlightSql.CommandGetDbSchemas) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
mergeFrom(FlightSql.CommandGetExportedKeys) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
mergeFrom(FlightSql.CommandGetImportedKeys) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
mergeFrom(FlightSql.CommandGetPrimaryKeys) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
mergeFrom(FlightSql.CommandGetSqlInfo) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
mergeFrom(FlightSql.CommandGetTables) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
mergeFrom(FlightSql.CommandGetTableTypes) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
mergeFrom(FlightSql.CommandGetXdbcTypeInfo) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
mergeFrom(FlightSql.CommandPreparedStatementQuery) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
mergeFrom(FlightSql.CommandPreparedStatementUpdate) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
mergeFrom(FlightSql.CommandStatementQuery) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
mergeFrom(FlightSql.CommandStatementSubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
mergeFrom(FlightSql.CommandStatementUpdate) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
mergeFrom(FlightSql.DoPutUpdateResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
mergeFrom(FlightSql.SubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
mergeFrom(FlightSql.TicketStatementQuery) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
mergeInfo(Flight.FlightInfo) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
mergeInfo(Flight.FlightInfo) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
mergePlan(FlightSql.SubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
mergePlan(FlightSql.SubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
mergeTicket(Flight.Ticket) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
Message - Class in org.apache.arrow.flatbuf
 
Message() - Constructor for class org.apache.arrow.flatbuf.Message
 
Message.Vector - Class in org.apache.arrow.flatbuf
 
MessageChannelReader - Class in org.apache.arrow.vector.ipc.message
Reads a sequence of messages using a ReadChannel.
MessageChannelReader(ReadChannel, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.message.MessageChannelReader
Construct a MessageReader to read streaming messages from an existing ReadChannel.
messageHasBody() - Method in class org.apache.arrow.vector.ipc.message.MessageMetadataResult
Check if the message is followed by a body.
MessageHeader - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- The root Message type This union enables us to easily send different message types without redundant storage, and in the future we can easily add new message types.
MessageMetadataResult - Class in org.apache.arrow.vector.ipc.message
Class to hold resulting Message metadata and buffer containing the serialized Flatbuffer message when reading messages from a ReadChannel.
MessageResult - Class in org.apache.arrow.vector.ipc.message
Class to hold the Message metadata and body data when reading messages through a MessageChannelReader.
MessageSerializer - Class in org.apache.arrow.vector.ipc.message
Utility class for serializing Messages.
MessageSerializer() - Constructor for class org.apache.arrow.vector.ipc.message.MessageSerializer
 
metadata() - Method in class org.apache.arrow.flight.CallStatus
Metadata associated with the exception.
metadata(ArrowBuf) - Static method in class org.apache.arrow.flight.PutResult
Create a PutResult with application-specific metadata.
MetadataAdapter - Class in org.apache.arrow.flight.grpc
A mutable adapter between the gRPC Metadata object and the Flight headers interface.
MetadataAdapter(Metadata) - Constructor for class org.apache.arrow.flight.grpc.MetadataAdapter
 
metaDataLength() - Method in class org.apache.arrow.flatbuf.Block
Length of the metadata
MetadataV4UnionChecker - Class in org.apache.arrow.vector.validate
Given a field, checks that no Union fields are present.
MetadataV4UnionChecker() - Constructor for class org.apache.arrow.vector.validate.MetadataV4UnionChecker
 
MetadataVersion - Class in org.apache.arrow.flatbuf
 
metadataVersion - Variable in class org.apache.arrow.vector.ipc.message.IpcOption
 
MetadataVersion - Enum in org.apache.arrow.vector.types
Metadata version for Arrow metadata.
method() - Method in class org.apache.arrow.flatbuf.BodyCompression
Indicates the way the record batch body was compressed
method() - Method in class org.apache.arrow.flight.CallInfo
 
MICROSECOND - Static variable in class org.apache.arrow.flatbuf.TimeUnit
 
middleware(FlightServerMiddleware.Key<T>, FlightServerMiddleware.Factory<T>) - Method in class org.apache.arrow.flight.FlightServer.Builder
Add a Flight middleware component to inspect and modify requests to this service.
MILLISECOND - Static variable in class org.apache.arrow.flatbuf.DateUnit
 
MILLISECOND - Static variable in class org.apache.arrow.flatbuf.TimeUnit
 
milliseconds - Variable in class org.apache.arrow.vector.holders.IntervalDayHolder
 
milliseconds - Variable in class org.apache.arrow.vector.holders.NullableIntervalDayHolder
 
MIN_SEGMENT_SIZE - Static variable in class org.apache.arrow.memory.rounding.SegmentRoundingPolicy
The minimal segment size.
minus_one - Static variable in class org.apache.arrow.vector.util.DecimalUtility
 
minutesToMillis - Static variable in class org.apache.arrow.vector.util.DateUtility
 
mode() - Method in class org.apache.arrow.flatbuf.Union
 
ModuleInfoCompilerPlugin - Class in org.apache.arrow.maven.plugins
A maven plugin for compiler module-info files in main code with JDK8.
ModuleInfoCompilerPlugin() - Constructor for class org.apache.arrow.maven.plugins.ModuleInfoCompilerPlugin
 
ModuleInfoTestCompilerPlugin - Class in org.apache.arrow.maven.plugins
A maven plugin for compiler module-info files in unit tests with JDK8.
ModuleInfoTestCompilerPlugin() - Constructor for class org.apache.arrow.maven.plugins.ModuleInfoTestCompilerPlugin
 
MONTH_DAY_NANO - Static variable in class org.apache.arrow.flatbuf.IntervalUnit
 
months - Variable in class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
 
months - Variable in class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
 
monthsToMillis - Static variable in class org.apache.arrow.vector.util.DateUtility
 
monthToStandardDays - Static variable in class org.apache.arrow.vector.util.DateUtility
 
moveWriterPosition() - Method in class org.apache.arrow.adapter.jdbc.consumer.BinaryConsumer
 
MultiMapWithOrdinal<K,V> - Class in org.apache.arrow.vector.util
An implementation of a multimap that supports constant time look-up by a generic key or an ordinal.
MultiMapWithOrdinal() - Constructor for class org.apache.arrow.vector.util.MultiMapWithOrdinal
 
MurmurHasher - Class in org.apache.arrow.memory.util.hash
Implementation of the Murmur hashing algorithm.
MurmurHasher() - Constructor for class org.apache.arrow.memory.util.hash.MurmurHasher
Creates a default Murmur hasher, with seed 0.
MurmurHasher(int) - Constructor for class org.apache.arrow.memory.util.hash.MurmurHasher
Creates a Murmur hasher.

N

name(int) - Static method in class org.apache.arrow.flatbuf.BodyCompressionMethod
 
name(int) - Static method in class org.apache.arrow.flatbuf.CompressionType
 
name(int) - Static method in class org.apache.arrow.flatbuf.DateUnit
 
name(int) - Static method in class org.apache.arrow.flatbuf.DictionaryKind
 
name(int) - Static method in class org.apache.arrow.flatbuf.Endianness
 
name() - Method in class org.apache.arrow.flatbuf.Field
Name is not required, in i.e.
name(int) - Static method in class org.apache.arrow.flatbuf.IntervalUnit
 
name(int) - Static method in class org.apache.arrow.flatbuf.MessageHeader
 
name(int) - Static method in class org.apache.arrow.flatbuf.MetadataVersion
 
name(int) - Static method in class org.apache.arrow.flatbuf.Precision
 
name(int) - Static method in class org.apache.arrow.flatbuf.SparseMatrixCompressedAxis
 
name(int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndex
 
name() - Method in class org.apache.arrow.flatbuf.TensorDim
Name of the dimension, optional
name(int) - Static method in class org.apache.arrow.flatbuf.TimeUnit
 
name(int) - Static method in class org.apache.arrow.flatbuf.Type
 
name(int) - Static method in class org.apache.arrow.flatbuf.UnionMode
 
name - Variable in class org.apache.arrow.vector.complex.AbstractContainerVector
 
NAME_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
nameAsByteBuffer() - Method in class org.apache.arrow.flatbuf.Field
 
nameAsByteBuffer() - Method in class org.apache.arrow.flatbuf.TensorDim
 
nameInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.Field
 
nameInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.TensorDim
 
names - Static variable in class org.apache.arrow.flatbuf.BodyCompressionMethod
 
names - Static variable in class org.apache.arrow.flatbuf.CompressionType
 
names - Static variable in class org.apache.arrow.flatbuf.DateUnit
 
names - Static variable in class org.apache.arrow.flatbuf.DictionaryKind
 
names - Static variable in class org.apache.arrow.flatbuf.Endianness
 
names - Static variable in class org.apache.arrow.flatbuf.IntervalUnit
 
names - Static variable in class org.apache.arrow.flatbuf.MessageHeader
 
names - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
 
names - Static variable in class org.apache.arrow.flatbuf.Precision
 
names - Static variable in class org.apache.arrow.flatbuf.SparseMatrixCompressedAxis
 
names - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
 
names - Static variable in class org.apache.arrow.flatbuf.TimeUnit
 
names - Static variable in class org.apache.arrow.flatbuf.Type
 
names - Static variable in class org.apache.arrow.flatbuf.UnionMode
 
NANOSECOND - Static variable in class org.apache.arrow.flatbuf.TimeUnit
 
nanoseconds - Variable in class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
 
nanoseconds - Variable in class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
 
nativeSQL(String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
needConvertToMessageFormat(Field) - Static method in class org.apache.arrow.vector.util.DictionaryUtility
Checks if it is required to convert the field to message format.
NettyAllocationManager - Class in org.apache.arrow.memory
The default implementation of AllocationManager.
NettyArrowBuf - Class in io.netty.buffer
Netty specific wrapper over ArrowBuf for use in Netty framework.
NettyArrowBuf(ArrowBuf, BufferAllocator, int) - Constructor for class io.netty.buffer.NettyArrowBuf
Constructs a new instance.
newBlockingStub(Channel) - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.apache.arrow.flight.TestServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
newBuilder(Flight.Action) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
newBuilder(Flight.ActionType) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
newBuilder(Flight.BasicAuth) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
newBuilder(Flight.CancelFlightInfoRequest) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
newBuilder(Flight.CancelFlightInfoResult) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
newBuilder(Flight.Criteria) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
newBuilder(Flight.Empty) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
newBuilder(Flight.FlightData) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
newBuilder(Flight.FlightDescriptor) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
newBuilder(Flight.FlightEndpoint) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
newBuilder(Flight.FlightInfo) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
newBuilder(Flight.HandshakeRequest) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
newBuilder(Flight.HandshakeResponse) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
newBuilder(Flight.Location) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
newBuilder(Flight.PollInfo) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
newBuilder(Flight.PutResult) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
newBuilder(Flight.RenewFlightEndpointRequest) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
newBuilder(Flight.Result) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
newBuilder(Flight.SchemaResult) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
newBuilder(Flight.Ticket) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
newBuilder() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
newBuilder(PerfOuterClass.Perf) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
newBuilder() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
newBuilder(PerfOuterClass.Token) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
newBuilder(FlightSql.ActionBeginSavepointRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
newBuilder(FlightSql.ActionBeginSavepointResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
newBuilder(FlightSql.ActionBeginTransactionRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
newBuilder(FlightSql.ActionBeginTransactionResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
newBuilder(FlightSql.ActionCancelQueryRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
newBuilder(FlightSql.ActionCancelQueryResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
newBuilder(FlightSql.ActionClosePreparedStatementRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
newBuilder(FlightSql.ActionCreatePreparedStatementRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
newBuilder(FlightSql.ActionCreatePreparedStatementResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
newBuilder(FlightSql.ActionCreatePreparedSubstraitPlanRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
newBuilder(FlightSql.ActionEndSavepointRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
newBuilder(FlightSql.ActionEndTransactionRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
newBuilder(FlightSql.CommandGetCatalogs) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
newBuilder(FlightSql.CommandGetCrossReference) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
newBuilder(FlightSql.CommandGetDbSchemas) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
newBuilder(FlightSql.CommandGetExportedKeys) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
newBuilder(FlightSql.CommandGetImportedKeys) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
newBuilder(FlightSql.CommandGetPrimaryKeys) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
newBuilder(FlightSql.CommandGetSqlInfo) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
newBuilder(FlightSql.CommandGetTables) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
newBuilder(FlightSql.CommandGetTableTypes) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
newBuilder(FlightSql.CommandGetXdbcTypeInfo) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
newBuilder(FlightSql.CommandPreparedStatementQuery) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
newBuilder(FlightSql.CommandPreparedStatementUpdate) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
newBuilder(FlightSql.CommandStatementQuery) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
newBuilder(FlightSql.CommandStatementSubstraitPlan) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
newBuilder(FlightSql.CommandStatementUpdate) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
newBuilder(FlightSql.DoPutUpdateResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
newBuilder(FlightSql.SubstraitPlan) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
newBuilder(FlightSql.TicketStatementQuery) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Action
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Location
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Result
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
newBuilderForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
newBuilderForType() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
newChildAllocator(String, long, long) - Method in interface org.apache.arrow.memory.BufferAllocator
Create a new child allocator.
newChildAllocator(String, AllocationListener, long, long) - Method in interface org.apache.arrow.memory.BufferAllocator
Create a new child allocator.
newConnection(UnregisteredDriver, AvaticaFactory, String, Properties) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
newDatabaseMetaData(AvaticaConnection) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
newDirectBuffer(int, int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
newFutureStub(Channel) - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.apache.arrow.flight.TestServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newHeapBuffer(int, int) - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.Action
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.Location
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.Result
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
newObjectMapper() - Static method in class org.apache.arrow.vector.util.ObjectMapperFactory
Creates a new ObjectMapper instance.
newPreparedStatement(AvaticaConnection, Meta.StatementHandle, Meta.Signature, int, int, int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
newReservation() - Method in interface org.apache.arrow.memory.BufferAllocator
Create an allocation reservation.
newResultSet(AvaticaStatement, QueryState, Meta.Signature, TimeZone, Meta.Frame) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
newResultSetMetaData(AvaticaStatement, Meta.Signature) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
newStatement(AvaticaConnection, Meta.StatementHandle, int, int, int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFactory
 
newStub(Channel) - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.apache.arrow.flight.TestServiceGrpc
Creates a new async stub that supports all call types for the service
next() - Method in class org.apache.arrow.adapter.jdbc.ArrowVectorIterator
Gets the next vector.
next() - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder
Bind the next row of data to the parameters of the statement.
next() - Method in class org.apache.arrow.AvroToArrowVectorIterator
Gets the next vector.
next() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcCursor
 
next() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcFlightStreamResultSet
 
next(long, TimeUnit) - Method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Blocking request with timeout to get the next ready FlightStream in queue.
next() - Method in class org.apache.arrow.driver.jdbc.utils.FlightEndpointDataQueue
Blocking request to get the next ready FlightStream in queue.
next() - Method in class org.apache.arrow.flight.FlightStream
Blocking request to load next item into list.
next() - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
next() - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
next() - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
next() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
next() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
next() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
next() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
next() - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
next() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedListReader
 
next() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedMapReader
 
next() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedStructReader
 
next() - Method in class org.apache.arrow.vector.table.Row
Returns the next non-deleted row in the table.
next() - Method in class org.apache.arrow.vector.util.ElementAddressableVectorIterator
Retrieves the next pointer from the vector.
next(ArrowBufPointer) - Method in class org.apache.arrow.vector.util.ElementAddressableVectorIterator
Retrieves the next pointer from the vector.
nextPowerOfTwo(int) - Static method in class org.apache.arrow.memory.util.CommonUtil
Rounds up the provided value to the nearest power of two.
nextPowerOfTwo(long) - Static method in class org.apache.arrow.memory.util.CommonUtil
Rounds up the provided value to the nearest power of two.
nioBuffer() - Method in class io.netty.buffer.NettyArrowBuf
 
nioBuffer(int, int) - Method in class io.netty.buffer.NettyArrowBuf
Returns a buffer that is zero positioned but points to a slice of the original buffer starting at given index.
nioBuffer(long, int) - Method in class io.netty.buffer.NettyArrowBuf
Returns a buffer that is zero positioned but points to a slice of the original buffer starting at given index.
nioBuffer() - Method in class org.apache.arrow.memory.ArrowBuf
Make a nio byte buffer from this arrowbuf.
nioBuffer(long, int) - Method in class org.apache.arrow.memory.ArrowBuf
Make a nio byte buffer from this ArrowBuf.
nioBufferCount() - Method in class io.netty.buffer.NettyArrowBuf
 
nioBuffers() - Method in class io.netty.buffer.NettyArrowBuf
 
nioBuffers(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
NO_ACTION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
NO_ACTION = 3;
NO_COMPRESSION_LENGTH - Static variable in class org.apache.arrow.vector.compression.CompressionUtil
Special flag to indicate no compression.
NO_LIMIT_BATCH_SIZE - Static variable in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
 
NO_LIMIT_BATCH_SIZE - Static variable in class org.apache.arrow.AvroToArrowVectorIterator
 
NO_OP - Static variable in interface org.apache.arrow.flight.auth.ServerAuthHandler
Deprecated.
An auth handler that does nothing.
NO_OP - Static variable in interface org.apache.arrow.flight.auth2.CallHeaderAuthenticator
An auth handler that does nothing.
NO_OP - Static variable in interface org.apache.arrow.flight.auth2.ClientHeaderHandler
An client header handler that does nothing.
NO_OP - Static variable in interface org.apache.arrow.memory.ReferenceManager
 
NO_OP_ERROR_MESSAGE - Static variable in interface org.apache.arrow.memory.ReferenceManager
 
NoCompressionCodec - Class in org.apache.arrow.vector.compression
The default compression codec that does no compression.
NoCompressionCodec.Factory - Class in org.apache.arrow.vector.compression
The default factory that creates a NoCompressionCodec.
nodes(int) - Method in class org.apache.arrow.flatbuf.RecordBatch
Nodes correspond to the pre-ordered flattened logical schema
nodes(FieldNode, int) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
nodesLength() - Method in class org.apache.arrow.flatbuf.RecordBatch
 
nodesVector() - Method in class org.apache.arrow.flatbuf.RecordBatch
 
nodesVector(FieldNode.Vector) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
NONE - Static variable in class org.apache.arrow.flatbuf.MessageHeader
 
NONE - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
 
NONE - Static variable in class org.apache.arrow.flatbuf.Type
 
NonNullableStructVector - Class in org.apache.arrow.vector.complex
A struct vector that has no null values (and no validity buffer).
NonNullableStructVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.NonNullableStructVector
Constructs a new instance.
NonNullableStructVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.NonNullableStructVector
Constructs a new instance.
NonNullableStructVector(String, BufferAllocator, FieldType, CallBack, AbstractStructVector.ConflictPolicy, boolean) - Constructor for class org.apache.arrow.vector.complex.NonNullableStructVector
Constructs a new instance.
NonNullableStructVector(Field, BufferAllocator, CallBack, AbstractStructVector.ConflictPolicy, boolean) - Constructor for class org.apache.arrow.vector.complex.NonNullableStructVector
Constructs a new instance.
NonNullableStructVector.StructTransferPair - Class in org.apache.arrow.vector.complex
TransferPair for this this class.
nonZeroLength() - Method in class org.apache.arrow.flatbuf.SparseTensor
The number of non-zero values in a sparse tensor.
NOOP - Static variable in interface org.apache.arrow.memory.AllocationListener
 
noop() - Static method in class org.apache.arrow.util.AutoCloseables
Get an AutoCloseable that does nothing.
NoOpFlightProducer - Class in org.apache.arrow.flight
A FlightProducer that throws on all operations.
NoOpFlightProducer() - Constructor for class org.apache.arrow.flight.NoOpFlightProducer
 
NoOpFlightSqlProducer - Class in org.apache.arrow.flight.sql
A FlightSqlProducer that throws on all FlightSql-specific operations.
NoOpFlightSqlProducer() - Constructor for class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
 
NoOpStreamListener<T> - Class in org.apache.arrow.flight
A FlightProducer.StreamListener that does nothing for all callbacks.
NoOpStreamListener() - Constructor for class org.apache.arrow.flight.NoOpStreamListener
 
NOT_FOUND - Static variable in class org.apache.arrow.flight.CallStatus
 
notNullable(String, ArrowType) - Static method in class org.apache.arrow.vector.types.pojo.Field
 
notNullable(ArrowType) - Static method in class org.apache.arrow.vector.types.pojo.FieldType
 
Null - Class in org.apache.arrow.flatbuf
These are stored in the flatbuffer in the Type union below
Null() - Constructor for class org.apache.arrow.flatbuf.Null
 
Null - Static variable in class org.apache.arrow.flatbuf.Type
 
Null() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
Null.Vector - Class in org.apache.arrow.flatbuf
 
NULL_CHECKING_ENABLED - Static variable in class org.apache.arrow.vector.NullCheckingForGet
The flag to indicate if null checking is enabled for "get" methods.
NULL_HASH_CODE - Static variable in class org.apache.arrow.memory.util.ArrowBufPointer
The hash code when the arrow buffer is null.
NULLABILITY_NO_NULLS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
Indicates that the fields does not allow the use of null values.
NULLABILITY_NULLABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
Indicates that the fields allow the use of null values.
NULLABILITY_UNKNOWN_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
Indicates that nullability of the fields cannot be determined.
nullable() - Method in class org.apache.arrow.flatbuf.Field
Whether or not this field can contain nulls.
nullable(String, ArrowType) - Static method in class org.apache.arrow.vector.types.pojo.Field
 
nullable(ArrowType) - Static method in class org.apache.arrow.vector.types.pojo.FieldType
 
NullableBigIntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableBigIntHolder() - Constructor for class org.apache.arrow.vector.holders.NullableBigIntHolder
 
NullableBigIntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableBigIntHolderReaderImpl(NullableBigIntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
NullableBitHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableBitHolder() - Constructor for class org.apache.arrow.vector.holders.NullableBitHolder
 
NullableBitHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableBitHolderReaderImpl(NullableBitHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
NullableCaseSensitiveStructWriter - Class in org.apache.arrow.vector.complex.impl
 
NullableCaseSensitiveStructWriter(StructVector) - Constructor for class org.apache.arrow.vector.complex.impl.NullableCaseSensitiveStructWriter
 
NullableColumnBinder - Class in org.apache.arrow.adapter.jdbc.binder
A ColumnBinder that checks for nullability before deferring to a type-specific binder.
NullableColumnBinder(ColumnBinder) - Constructor for class org.apache.arrow.adapter.jdbc.binder.NullableColumnBinder
 
NullableDateDayHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableDateDayHolder() - Constructor for class org.apache.arrow.vector.holders.NullableDateDayHolder
 
NullableDateDayHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableDateDayHolderReaderImpl(NullableDateDayHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
NullableDateMilliHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableDateMilliHolder() - Constructor for class org.apache.arrow.vector.holders.NullableDateMilliHolder
 
NullableDateMilliHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableDateMilliHolderReaderImpl(NullableDateMilliHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
NullableDecimal256Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableDecimal256Holder() - Constructor for class org.apache.arrow.vector.holders.NullableDecimal256Holder
 
NullableDecimal256HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableDecimal256HolderReaderImpl(NullableDecimal256Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
NullableDecimalHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableDecimalHolder() - Constructor for class org.apache.arrow.vector.holders.NullableDecimalHolder
 
NullableDecimalHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableDecimalHolderReaderImpl(NullableDecimalHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
NullableDurationHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableDurationHolder() - Constructor for class org.apache.arrow.vector.holders.NullableDurationHolder
 
NullableDurationHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableDurationHolderReaderImpl(NullableDurationHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
NullableFixedSizeBinaryHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableFixedSizeBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
 
NullableFixedSizeBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableFixedSizeBinaryHolderReaderImpl(NullableFixedSizeBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
NullableFloat4Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableFloat4Holder() - Constructor for class org.apache.arrow.vector.holders.NullableFloat4Holder
 
NullableFloat4HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableFloat4HolderReaderImpl(NullableFloat4Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
NullableFloat8Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableFloat8Holder() - Constructor for class org.apache.arrow.vector.holders.NullableFloat8Holder
 
NullableFloat8HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableFloat8HolderReaderImpl(NullableFloat8Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
NullableIntervalDayHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableIntervalDayHolder() - Constructor for class org.apache.arrow.vector.holders.NullableIntervalDayHolder
 
NullableIntervalDayHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableIntervalDayHolderReaderImpl(NullableIntervalDayHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
NullableIntervalMonthDayNanoHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableIntervalMonthDayNanoHolder() - Constructor for class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
 
NullableIntervalMonthDayNanoHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableIntervalMonthDayNanoHolderReaderImpl(NullableIntervalMonthDayNanoHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
NullableIntervalYearHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableIntervalYearHolder() - Constructor for class org.apache.arrow.vector.holders.NullableIntervalYearHolder
 
NullableIntervalYearHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableIntervalYearHolderReaderImpl(NullableIntervalYearHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
NullableIntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableIntHolder() - Constructor for class org.apache.arrow.vector.holders.NullableIntHolder
 
NullableIntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableIntHolderReaderImpl(NullableIntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
NullableLargeVarBinaryHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableLargeVarBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
 
NullableLargeVarBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableLargeVarBinaryHolderReaderImpl(NullableLargeVarBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
NullableLargeVarCharHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableLargeVarCharHolder() - Constructor for class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
 
NullableLargeVarCharHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableLargeVarCharHolderReaderImpl(NullableLargeVarCharHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
nullablePrimitive(String, ArrowType.PrimitiveType) - Static method in class org.apache.arrow.vector.types.pojo.Field
 
NullableSmallIntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableSmallIntHolder() - Constructor for class org.apache.arrow.vector.holders.NullableSmallIntHolder
 
NullableSmallIntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableSmallIntHolderReaderImpl(NullableSmallIntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
NullableStructReaderImpl - Class in org.apache.arrow.vector.complex.impl
An FieldReader for reading nullable struct vectors.
NullableStructReaderImpl(NonNullableStructVector) - Constructor for class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
 
NullableStructTransferPair(StructVector, StructVector, boolean) - Constructor for class org.apache.arrow.vector.complex.StructVector.NullableStructTransferPair
 
NullableStructWriter - Class in org.apache.arrow.vector.complex.impl
 
NullableStructWriter(StructVector) - Constructor for class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
NullableStructWriterFactory - Class in org.apache.arrow.vector.complex.impl
A factory for NullableStructWriter instances.
NullableStructWriterFactory(boolean) - Constructor for class org.apache.arrow.vector.complex.impl.NullableStructWriterFactory
 
NullableTimeMicroHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeMicroHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeMicroHolder
 
NullableTimeMicroHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeMicroHolderReaderImpl(NullableTimeMicroHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
NullableTimeMilliHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeMilliHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeMilliHolder
 
NullableTimeMilliHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeMilliHolderReaderImpl(NullableTimeMilliHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
NullableTimeNanoHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeNanoHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeNanoHolder
 
NullableTimeNanoHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeNanoHolderReaderImpl(NullableTimeNanoHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
NullableTimeSecHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeSecHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeSecHolder
 
NullableTimeSecHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeSecHolderReaderImpl(NullableTimeSecHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
NullableTimeStampMicroHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampMicroHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampMicroHolder
 
NullableTimeStampMicroHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampMicroHolderReaderImpl(NullableTimeStampMicroHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
NullableTimeStampMicroTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampMicroTZHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampMicroTZHolder
 
NullableTimeStampMicroTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampMicroTZHolderReaderImpl(NullableTimeStampMicroTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
NullableTimeStampMilliHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampMilliHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampMilliHolder
 
NullableTimeStampMilliHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampMilliHolderReaderImpl(NullableTimeStampMilliHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
NullableTimeStampMilliTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampMilliTZHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampMilliTZHolder
 
NullableTimeStampMilliTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampMilliTZHolderReaderImpl(NullableTimeStampMilliTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
NullableTimeStampNanoHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampNanoHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampNanoHolder
 
NullableTimeStampNanoHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampNanoHolderReaderImpl(NullableTimeStampNanoHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
NullableTimeStampNanoTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampNanoTZHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampNanoTZHolder
 
NullableTimeStampNanoTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampNanoTZHolderReaderImpl(NullableTimeStampNanoTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
NullableTimeStampSecHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampSecHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampSecHolder
 
NullableTimeStampSecHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampSecHolderReaderImpl(NullableTimeStampSecHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
NullableTimeStampSecTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTimeStampSecTZHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTimeStampSecTZHolder
 
NullableTimeStampSecTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTimeStampSecTZHolderReaderImpl(NullableTimeStampSecTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
NullableTinyIntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableTinyIntHolder() - Constructor for class org.apache.arrow.vector.holders.NullableTinyIntHolder
 
NullableTinyIntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableTinyIntHolderReaderImpl(NullableTinyIntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
NullableUInt1Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableUInt1Holder() - Constructor for class org.apache.arrow.vector.holders.NullableUInt1Holder
 
NullableUInt1HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableUInt1HolderReaderImpl(NullableUInt1Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
NullableUInt2Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableUInt2Holder() - Constructor for class org.apache.arrow.vector.holders.NullableUInt2Holder
 
NullableUInt2HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableUInt2HolderReaderImpl(NullableUInt2Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
NullableUInt4Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableUInt4Holder() - Constructor for class org.apache.arrow.vector.holders.NullableUInt4Holder
 
NullableUInt4HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableUInt4HolderReaderImpl(NullableUInt4Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
NullableUInt8Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableUInt8Holder() - Constructor for class org.apache.arrow.vector.holders.NullableUInt8Holder
 
NullableUInt8HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableUInt8HolderReaderImpl(NullableUInt8Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
NullableVarBinaryHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableVarBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.NullableVarBinaryHolder
 
NullableVarBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableVarBinaryHolderReaderImpl(NullableVarBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
NullableVarCharHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
NullableVarCharHolder() - Constructor for class org.apache.arrow.vector.holders.NullableVarCharHolder
 
NullableVarCharHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
NullableVarCharHolderReaderImpl(NullableVarCharHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
NullAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Null Arrow types.
NullAvaticaParameterConverter(ArrowType.Null) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.NullAvaticaParameterConverter
 
NullCheckingForGet - Class in org.apache.arrow.vector
Configuration class to determine if null checking should be enabled or disabled for the "get" methods.
NullComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.NullComparator
 
NullConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume null type values from ResultSet.
NullConsumer(NullVector) - Constructor for class org.apache.arrow.adapter.jdbc.consumer.NullConsumer
 
nullCount() - Method in class org.apache.arrow.flatbuf.FieldNode
The number of observed nulls.
nullPlusNonNullIsNull() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
NullReader - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template NullReader.java
NullVector - Class in org.apache.arrow.vector
A null type vector.
NullVector(String) - Constructor for class org.apache.arrow.vector.NullVector
Instantiate a NullVector.
NullVector(String, int) - Constructor for class org.apache.arrow.vector.NullVector
Instantiate a NullVector with the given number of values.
NullVector(String, FieldType) - Constructor for class org.apache.arrow.vector.NullVector
Instantiate a NullVector.
NullVector(Field) - Constructor for class org.apache.arrow.vector.NullVector
Instantiate a NullVector.
NullVector(Field, int) - Constructor for class org.apache.arrow.vector.NullVector
Instantiate a NullVector with the given number of values.
NullVector() - Constructor for class org.apache.arrow.vector.NullVector
Deprecated.

O

ObjectMapperFactory - Class in org.apache.arrow.vector.util
A ObjectMapper factory to read/write JSON.
of(String) - Static method in class org.apache.arrow.flight.FlightServerMiddleware.Key
Create a new key for the given type.
of(String, String, String) - Static method in class org.apache.arrow.flight.sql.util.TableRef
A static initializer of the TableRef with all the arguments.
of(FieldVector...) - Static method in class org.apache.arrow.vector.table.Table
Constructs a new instance from vectors.
of(FieldVector...) - Static method in class org.apache.arrow.vector.VectorSchemaRoot
Constructs a new instance from vectors.
offset() - Method in class org.apache.arrow.flatbuf.Block
Index to the start of the RecordBlock (note this is past the Message header)
offset() - Method in class org.apache.arrow.flatbuf.Buffer
The relative offset into the shared memory page where the bytes for this buffer starts
OFFSET_WIDTH - Static variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
OFFSET_WIDTH - Static variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
OFFSET_WIDTH - Static variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
OFFSET_WIDTH - Static variable in class org.apache.arrow.vector.complex.DenseUnionVector
 
OFFSET_WIDTH - Static variable in class org.apache.arrow.vector.complex.LargeListVector
 
offsetAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
offsetAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
offsetBuffer - Variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
offsetBuffer - Variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
offsetBuffer() - Static method in class org.apache.arrow.vector.BufferLayout
 
offsetBuffer - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
offsetBuffer - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
ok() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.ComplexReader
 
onAllocation(long) - Method in interface org.apache.arrow.memory.AllocationListener
Called each time a new buffer has been allocated.
onBeforeSendingHeaders(CallHeaders) - Method in class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware
 
onBeforeSendingHeaders(CallHeaders) - Method in class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware
 
onBeforeSendingHeaders(CallHeaders) - Method in class org.apache.arrow.flight.client.ClientCookieMiddleware
 
onBeforeSendingHeaders(CallHeaders) - Method in interface org.apache.arrow.flight.FlightClientMiddleware
A callback used before request headers are sent.
onBeforeSendingHeaders(CallHeaders) - Method in interface org.apache.arrow.flight.FlightServerMiddleware
Callback for when the underlying transport is about to send response headers.
onBeforeSendingHeaders(CallHeaders) - Method in class org.apache.arrow.flight.ServerHeaderMiddleware
 
onCallCompleted(CallStatus) - Method in class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware
 
onCallCompleted(CallStatus) - Method in class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware
 
onCallCompleted(CallStatus) - Method in class org.apache.arrow.flight.client.ClientCookieMiddleware
 
onCallCompleted(CallStatus) - Method in interface org.apache.arrow.flight.FlightClientMiddleware
A callback called after the call completes.
onCallCompleted(CallStatus) - Method in interface org.apache.arrow.flight.FlightServerMiddleware
Callback for when the underlying transport has completed a call.
onCallCompleted(CallStatus) - Method in class org.apache.arrow.flight.ServerHeaderMiddleware
 
onCallErrored(Throwable) - Method in class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware
 
onCallErrored(Throwable) - Method in interface org.apache.arrow.flight.FlightServerMiddleware
Callback for when an RPC method implementation throws an uncaught exception.
onCallErrored(Throwable) - Method in class org.apache.arrow.flight.ServerHeaderMiddleware
 
onCallStarted(CallInfo) - Method in class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware.Factory
 
onCallStarted(CallInfo, CallHeaders, RequestContext) - Method in class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware.Factory
 
onCallStarted(CallInfo) - Method in class org.apache.arrow.flight.client.ClientCookieMiddleware.Factory
 
onCallStarted(CallInfo) - Method in interface org.apache.arrow.flight.FlightClientMiddleware.Factory
Create a new middleware instance for the given call.
onCallStarted(CallInfo, CallHeaders, RequestContext) - Method in interface org.apache.arrow.flight.FlightServerMiddleware.Factory
A callback for when the call starts.
onCallStarted(CallInfo, CallHeaders, RequestContext) - Method in class org.apache.arrow.flight.ServerHeaderMiddleware.Factory
 
onChildAdded(BufferAllocator, BufferAllocator) - Method in interface org.apache.arrow.memory.AllocationListener
Called immediately after a child allocator was added to the parent allocator.
onChildRemoved(BufferAllocator, BufferAllocator) - Method in interface org.apache.arrow.memory.AllocationListener
Called immediately after a child allocator was removed from the parent allocator.
onCompleted() - Method in class org.apache.arrow.flight.AsyncPutListener
 
onCompleted() - Method in interface org.apache.arrow.flight.FlightProducer.StreamListener
Indicate that the transmission is finished.
onCompleted() - Method in class org.apache.arrow.flight.NoOpStreamListener
Ignores the stream completion event.
onCompleted() - Method in class org.apache.arrow.flight.sql.FlightEndpointListener
 
onCompleted() - Method in class org.apache.arrow.flight.SyncPutListener
 
onError(Throwable) - Method in class org.apache.arrow.flight.AsyncPutListener
 
onError(Throwable) - Method in interface org.apache.arrow.flight.auth.ClientAuthHandler.ClientAuthSender
Deprecated.
Signal an error to the server and abort the authentication attempt.
onError(Throwable) - Method in interface org.apache.arrow.flight.auth.ServerAuthHandler.ServerAuthSender
Deprecated.
 
onError(Throwable) - Method in interface org.apache.arrow.flight.FlightProducer.StreamListener
Indicate an error to the client.
onError(Throwable) - Method in class org.apache.arrow.flight.NoOpStreamListener
Ignores the error received.
onError(Throwable) - Method in class org.apache.arrow.flight.sql.FlightEndpointListener
 
onError(Throwable) - Method in class org.apache.arrow.flight.SyncPutListener
 
onFailedAllocation(long, AllocationOutcome) - Method in interface org.apache.arrow.memory.AllocationListener
Called whenever an allocation failed, giving the caller a chance to create some space in the allocator (either by freeing some resource, or by changing the limit), and, if successful, allowing the allocator to retry the allocation.
onHeadersReceived(CallHeaders) - Method in class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware
 
onHeadersReceived(CallHeaders) - Method in class org.apache.arrow.flight.client.ClientCookieMiddleware
 
onHeadersReceived(CallHeaders) - Method in interface org.apache.arrow.flight.FlightClientMiddleware
A callback called after response headers are received.
onNext(PutResult) - Method in class org.apache.arrow.flight.AsyncPutListener
 
onNext(PutResult) - Method in interface org.apache.arrow.flight.FlightClient.PutListener
Called when a message from the server is received.
onNext(T) - Method in interface org.apache.arrow.flight.FlightProducer.StreamListener
Send the next value to the client.
onNext(T) - Method in class org.apache.arrow.flight.NoOpStreamListener
Ignores the value received.
onNext(FlightEndpoint) - Method in class org.apache.arrow.flight.sql.FlightEndpointListener
 
onNext(PutResult) - Method in class org.apache.arrow.flight.SyncPutListener
 
onPreAllocation(long) - Method in interface org.apache.arrow.memory.AllocationListener
Called each time a new buffer has been requested.
onRelease(long) - Method in interface org.apache.arrow.memory.AllocationListener
Informed each time a buffer is released from allocation.
open() - Method in class org.apache.arrow.memory.util.AutoCloseableLock
 
option - Variable in class org.apache.arrow.vector.ipc.ArrowWriter
 
order() - Method in class io.netty.buffer.NettyArrowBuf
 
order(ByteOrder) - Method in class io.netty.buffer.NettyArrowBuf
 
order(ByteOrder) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
order() - Method in class org.apache.arrow.memory.ArrowBuf
Returns the byte order of elements in this buffer.
ORDERED_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
OrderedScenario - Class in org.apache.arrow.flight.integration.tests
Test the 'ordered' flag in FlightInfo.
OrderedScenario() - Constructor for class org.apache.arrow.flight.integration.tests.OrderedScenario
 
ordinal - Variable in class org.apache.arrow.vector.complex.VectorWithOrdinal
 
org.apache.arrow - package org.apache.arrow
 
org.apache.arrow.adapter.jdbc - package org.apache.arrow.adapter.jdbc
 
org.apache.arrow.adapter.jdbc.binder - package org.apache.arrow.adapter.jdbc.binder
Utilities to bind Arrow data as JDBC prepared statement parameters.
org.apache.arrow.adapter.jdbc.consumer - package org.apache.arrow.adapter.jdbc.consumer
 
org.apache.arrow.adapter.jdbc.consumer.exceptions - package org.apache.arrow.adapter.jdbc.consumer.exceptions
 
org.apache.arrow.algorithm.deduplicate - package org.apache.arrow.algorithm.deduplicate
 
org.apache.arrow.algorithm.dictionary - package org.apache.arrow.algorithm.dictionary
 
org.apache.arrow.algorithm.misc - package org.apache.arrow.algorithm.misc
 
org.apache.arrow.algorithm.rank - package org.apache.arrow.algorithm.rank
 
org.apache.arrow.algorithm.search - package org.apache.arrow.algorithm.search
 
org.apache.arrow.algorithm.sort - package org.apache.arrow.algorithm.sort
 
org.apache.arrow.compression - package org.apache.arrow.compression
 
org.apache.arrow.consumers - package org.apache.arrow.consumers
 
org.apache.arrow.consumers.logical - package org.apache.arrow.consumers.logical
 
org.apache.arrow.driver.jdbc - package org.apache.arrow.driver.jdbc
 
org.apache.arrow.driver.jdbc.accessor - package org.apache.arrow.driver.jdbc.accessor
 
org.apache.arrow.driver.jdbc.accessor.impl - package org.apache.arrow.driver.jdbc.accessor.impl
 
org.apache.arrow.driver.jdbc.accessor.impl.binary - package org.apache.arrow.driver.jdbc.accessor.impl.binary
 
org.apache.arrow.driver.jdbc.accessor.impl.calendar - package org.apache.arrow.driver.jdbc.accessor.impl.calendar
 
org.apache.arrow.driver.jdbc.accessor.impl.complex - package org.apache.arrow.driver.jdbc.accessor.impl.complex
 
org.apache.arrow.driver.jdbc.accessor.impl.numeric - package org.apache.arrow.driver.jdbc.accessor.impl.numeric
 
org.apache.arrow.driver.jdbc.accessor.impl.text - package org.apache.arrow.driver.jdbc.accessor.impl.text
 
org.apache.arrow.driver.jdbc.client - package org.apache.arrow.driver.jdbc.client
 
org.apache.arrow.driver.jdbc.client.utils - package org.apache.arrow.driver.jdbc.client.utils
 
org.apache.arrow.driver.jdbc.converter - package org.apache.arrow.driver.jdbc.converter
 
org.apache.arrow.driver.jdbc.converter.impl - package org.apache.arrow.driver.jdbc.converter.impl
 
org.apache.arrow.driver.jdbc.utils - package org.apache.arrow.driver.jdbc.utils
 
org.apache.arrow.flatbuf - package org.apache.arrow.flatbuf
 
org.apache.arrow.flight - package org.apache.arrow.flight
 
org.apache.arrow.flight.auth - package org.apache.arrow.flight.auth
 
org.apache.arrow.flight.auth2 - package org.apache.arrow.flight.auth2
 
org.apache.arrow.flight.client - package org.apache.arrow.flight.client
 
org.apache.arrow.flight.grpc - package org.apache.arrow.flight.grpc
 
org.apache.arrow.flight.impl - package org.apache.arrow.flight.impl
 
org.apache.arrow.flight.integration.tests - package org.apache.arrow.flight.integration.tests
 
org.apache.arrow.flight.perf.impl - package org.apache.arrow.flight.perf.impl
 
org.apache.arrow.flight.sql - package org.apache.arrow.flight.sql
 
org.apache.arrow.flight.sql.example - package org.apache.arrow.flight.sql.example
 
org.apache.arrow.flight.sql.impl - package org.apache.arrow.flight.sql.impl
 
org.apache.arrow.flight.sql.util - package org.apache.arrow.flight.sql.util
 
org.apache.arrow.maven.plugins - package org.apache.arrow.maven.plugins
 
org.apache.arrow.memory - package org.apache.arrow.memory
Memory Allocation, Accounting and Management.
org.apache.arrow.memory.rounding - package org.apache.arrow.memory.rounding
 
org.apache.arrow.memory.util - package org.apache.arrow.memory.util
 
org.apache.arrow.memory.util.hash - package org.apache.arrow.memory.util.hash
 
org.apache.arrow.tools - package org.apache.arrow.tools
 
org.apache.arrow.util - package org.apache.arrow.util
 
org.apache.arrow.vector - package org.apache.arrow.vector
 
org.apache.arrow.vector.compare - package org.apache.arrow.vector.compare
 
org.apache.arrow.vector.compare.util - package org.apache.arrow.vector.compare.util
 
org.apache.arrow.vector.complex - package org.apache.arrow.vector.complex
 
org.apache.arrow.vector.complex.impl - package org.apache.arrow.vector.complex.impl
 
org.apache.arrow.vector.complex.reader - package org.apache.arrow.vector.complex.reader
 
org.apache.arrow.vector.complex.writer - package org.apache.arrow.vector.complex.writer
 
org.apache.arrow.vector.compression - package org.apache.arrow.vector.compression
 
org.apache.arrow.vector.dictionary - package org.apache.arrow.vector.dictionary
 
org.apache.arrow.vector.holders - package org.apache.arrow.vector.holders
 
org.apache.arrow.vector.ipc - package org.apache.arrow.vector.ipc
 
org.apache.arrow.vector.ipc.message - package org.apache.arrow.vector.ipc.message
 
org.apache.arrow.vector.table - package org.apache.arrow.vector.table
 
org.apache.arrow.vector.types - package org.apache.arrow.vector.types
 
org.apache.arrow.vector.types.pojo - package org.apache.arrow.vector.types.pojo
 
org.apache.arrow.vector.util - package org.apache.arrow.vector.util
 
org.apache.arrow.vector.validate - package org.apache.arrow.vector.validate
 
out - Variable in class org.apache.arrow.vector.ipc.ArrowWriter
 
OutboundStreamListener - Interface in org.apache.arrow.flight
An interface for writing data to a peer, client or server.
OutOfMemoryException - Exception in org.apache.arrow.memory
Indicates memory could not be allocated for Arrow buffers.
OutOfMemoryException() - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
 
OutOfMemoryException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
 
OutOfMemoryException(String, Throwable) - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
 
OutOfMemoryException(String) - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
 
OutOfMemoryException(String, Optional<AllocationOutcomeDetails>) - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
 
OutOfMemoryException(Throwable) - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
 
OutOfPlaceVectorSorter<V extends ValueVector> - Interface in org.apache.arrow.algorithm.sort
Basic interface for sorting a vector out-of-place.
overrideHostname(String) - Method in class org.apache.arrow.flight.FlightClient.Builder
Override the hostname checked for TLS.
OversizedAllocationException - Exception in org.apache.arrow.vector.util
An exception that is used to signal that allocation request in bytes is greater than the maximum allowed by allocator.
OversizedAllocationException() - Constructor for exception org.apache.arrow.vector.util.OversizedAllocationException
 
OversizedAllocationException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.arrow.vector.util.OversizedAllocationException
 
OversizedAllocationException(String, Throwable) - Constructor for exception org.apache.arrow.vector.util.OversizedAllocationException
 
OversizedAllocationException(String) - Constructor for exception org.apache.arrow.vector.util.OversizedAllocationException
 
OversizedAllocationException(Throwable) - Constructor for exception org.apache.arrow.vector.util.OversizedAllocationException
 
OwnershipTransferNOOP - Class in org.apache.arrow.memory
An OwnershipTransferResult indicating no transfer needed.
OwnershipTransferResult - Interface in org.apache.arrow.memory
The result of transferring an ArrowBuf between BufferAllocators.

P

packageRawBuffer(BufferAllocator, ArrowBuf) - Static method in class org.apache.arrow.vector.compression.CompressionUtil
Process compression by compressing the buffer as is.
ParallelSearcher<V extends ValueVector> - Class in org.apache.arrow.algorithm.search
Search for a value in the vector by multiple threads.
ParallelSearcher(V, ExecutorService, int) - Constructor for class org.apache.arrow.algorithm.search.ParallelSearcher
Constructs a parallel searcher.
PARAMETER_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parse(String, String) - Static method in class org.apache.arrow.driver.jdbc.utils.UrlParser
Parse URL key value parameters.
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
parseOrThrow(byte[]) - Static method in class org.apache.arrow.flight.sql.FlightSqlUtils
Helper to parse Any objects to the specific protobuf object.
parser() - Static method in class org.apache.arrow.flight.impl.Flight.Action
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.Empty
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.Location
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.Result
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
parser() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
 
parser() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
parser() - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
PartialSumUtils - Class in org.apache.arrow.algorithm.misc
Partial sum related utilities.
partition(int, int, IntVector, VectorValueComparator<T>) - Static method in class org.apache.arrow.algorithm.sort.IndexSorter
Partition a range of values in a vector into two parts, with elements in one part smaller than elements from the other part.
PASSWORD_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
path(Iterable<String>) - Static method in class org.apache.arrow.flight.FlightDescriptor
 
path(String...) - Static method in class org.apache.arrow.flight.FlightDescriptor
 
PATH_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
PATH_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
A named path that identifies a dataset.
PAYLOAD_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
PEER_IDENTITY_KEY - Static variable in class org.apache.arrow.flight.auth.AuthConstants
 
PEER_IDENTITY_KEY - Static variable in class org.apache.arrow.flight.auth2.Auth2Constants
 
peerIdentity() - Method in interface org.apache.arrow.flight.FlightProducer.CallContext
The identity of the authenticated peer.
PerfOuterClass - Class in org.apache.arrow.flight.perf.impl
 
PerfOuterClass.Perf - Class in org.apache.arrow.flight.perf.impl
Protobuf type Perf
PerfOuterClass.Perf.Builder - Class in org.apache.arrow.flight.perf.impl
Protobuf type Perf
PerfOuterClass.PerfOrBuilder - Interface in org.apache.arrow.flight.perf.impl
 
PerfOuterClass.Token - Class in org.apache.arrow.flight.perf.impl
Payload of ticket
PerfOuterClass.Token.Builder - Class in org.apache.arrow.flight.perf.impl
Payload of ticket
PerfOuterClass.TokenOrBuilder - Interface in org.apache.arrow.flight.perf.impl
 
PeriodDuration - Class in org.apache.arrow.vector
Combination of Period and Duration for representing this interval type as a POJO.
PeriodDuration(Period, Duration) - Constructor for class org.apache.arrow.vector.PeriodDuration
 
PK_CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
PK_DB_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
PK_TABLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
PLAN_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
PLAN_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
PLAN_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
poll(long, TimeUnit) - Method in class org.apache.arrow.flight.SyncPutListener
Get the next message from the server, blocking for the specified amount of time until it is available.
pollFlightInfo(FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.FlightProducer
Begin or get an update on execution of a long-running query.
pollFlightInfo(Flight.FlightDescriptor, StreamObserver<Flight.PollInfo>) - Method in interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
For a given FlightDescriptor, start a query and get information to poll its execution status.
pollFlightInfo(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceBlockingStub
For a given FlightDescriptor, start a query and get information to poll its execution status.
pollFlightInfo(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceFutureStub
For a given FlightDescriptor, start a query and get information to poll its execution status.
pollFlightInfo(Flight.FlightDescriptor, StreamObserver<Flight.PollInfo>) - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceStub
For a given FlightDescriptor, start a query and get information to poll its execution status.
pollInfo(FlightDescriptor, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Start or get info on execution of a long-running query.
PollInfo - Class in org.apache.arrow.flight
A POJO representation of the execution of a long-running query.
PollInfo(FlightInfo, FlightDescriptor, Double, Instant) - Constructor for class org.apache.arrow.flight.PollInfo
Create a new PollInfo.
PooledByteBufAllocatorL - Class in io.netty.buffer
The base allocator that we use for all of Arrow's memory management.
PooledByteBufAllocatorL() - Constructor for class io.netty.buffer.PooledByteBufAllocatorL
 
populate(int) - Method in class org.apache.arrow.vector.complex.EmptyValuePopulator
Marks all values since the last set as empty.
populateDeduplicatedValues(V) - Method in class org.apache.arrow.algorithm.deduplicate.VectorRunDeduplicator
Gets the vector with deduplicated adjacent values removed.
populateRunLengths(IntVector) - Method in class org.apache.arrow.algorithm.deduplicate.VectorRunDeduplicator
Gets the length of each distinct value.
populateSortedDictionary(V) - Method in class org.apache.arrow.algorithm.dictionary.SearchTreeBasedDictionaryBuilder
Gets the sorted dictionary.
port() - Method in class org.apache.arrow.tools.EchoServer
 
position() - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
position(long) - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
Positionable - Interface in org.apache.arrow.vector.complex
Get and set position in a particular data structure.
preAllocate(VectorSchemaRoot, int) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Pre allocate memory for BaseFixedWidthVector.
precision() - Method in class org.apache.arrow.flatbuf.Decimal
Total number of decimal digits
precision() - Method in class org.apache.arrow.flatbuf.FloatingPoint
 
Precision - Class in org.apache.arrow.flatbuf
 
precision(int) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets the precision / column size.
precision - Variable in class org.apache.arrow.vector.holders.Decimal256Holder
 
precision - Variable in class org.apache.arrow.vector.holders.DecimalHolder
 
precision - Variable in class org.apache.arrow.vector.holders.NullableDecimal256Holder
 
precision - Variable in class org.apache.arrow.vector.holders.NullableDecimalHolder
 
Preconditions - Class in org.apache.arrow.util
Static convenience methods that help a method or constructor check whether it was invoked correctly (whether its preconditions have been met).
prepare(Meta.ConnectionHandle, String, long) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
prepare(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler
Creates a new ArrowFlightSqlClientHandler.PreparedStatement for the given query.
prepare(String, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Create a prepared statement for a SQL query on the server.
prepare(String, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Create a prepared statement for a SQL query on the server.
prepare(FlightSqlClient.SubstraitPlan, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Create a prepared statement for a Substrait plan on the server.
prepare(FlightSqlClient.SubstraitPlan, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Create a prepared statement for a Substrait plan on the server.
prepareAndExecute(Meta.StatementHandle, String, long, Meta.PrepareCallback) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
prepareAndExecute(Meta.StatementHandle, String, long, int, Meta.PrepareCallback) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
prepareAndExecuteBatch(Meta.StatementHandle, List<String>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
prepareCall(String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
prepareCall(String, int, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
prepareCall(String, int, int, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
PREPARED_STATEMENT_HANDLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
PREPARED_STATEMENT_HANDLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
PREPARED_STATEMENT_HANDLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
PREPARED_STATEMENT_HANDLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
prepareLoadNextBatch() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Ensure the reader has been initialized and reset the VectorSchemaRoot row count to 0.
prepareStatement(String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
prepareStatement(String, int, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
prepareStatement(String, int, int, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
prepareStatement(String, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
prepareStatement(String, int...) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
prepareStatement(String, String...) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
pretty(boolean) - Method in class org.apache.arrow.vector.ipc.JsonFileWriter.JSONWriteConfig
 
PrimitiveTypeVisitor() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
print(StringBuilder, int, BaseAllocator.Verbosity) - Method in class org.apache.arrow.memory.ArrowBuf
Print information of this buffer into sb at the given indentation and verbosity level.
print(StringBuilder, int) - Method in class org.apache.arrow.memory.ArrowBuf
Print detailed information of this buffer into sb.
producer(FlightProducer) - Method in class org.apache.arrow.flight.FlightServer.Builder
 
producer(BufferAllocator, Location) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
producer(BufferAllocator, Location) - Method in class org.apache.arrow.flight.integration.tests.OrderedScenario
 
PROGRESS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.PollInfo
 
PromotableMultiMapWithOrdinal<K,V> - Class in org.apache.arrow.vector.util
Implementation of MapWithOrdinal that allows for promotion to multimap when duplicate fields exist.
PromotableMultiMapWithOrdinal(boolean, AbstractStructVector.ConflictPolicy) - Constructor for class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
Create promotable map.
PromotableVector - Interface in org.apache.arrow.vector.complex
Vector that can store multiple FieldType vectors as children.
PromotableWriter - Class in org.apache.arrow.vector.complex.impl
This FieldWriter implementation delegates all FieldWriter API calls to an inner FieldWriter.
PromotableWriter(ValueVector, AbstractStructVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
PromotableWriter(ValueVector, AbstractStructVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
PromotableWriter(ValueVector, ListVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
PromotableWriter(ValueVector, FixedSizeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
PromotableWriter(ValueVector, LargeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
PromotableWriter(ValueVector, ListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
PromotableWriter(ValueVector, FixedSizeListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
PromotableWriter(ValueVector, LargeListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
Constructs a new instance.
promoteToUnion() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
promoteToUnion() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
promoteToUnion() - Method in class org.apache.arrow.vector.complex.ListVector
 
promoteToUnion() - Method in interface org.apache.arrow.vector.complex.PromotableVector
 
PROMOTION_MASK - Static variable in class org.apache.arrow.vector.UInt1Vector
The mask to use when promoting the unsigned byte value to an integer.
PROMOTION_MASK - Static variable in class org.apache.arrow.vector.UInt4Vector
The mask to use when promoting the unsigned int value to a long int.
PROTOCOL_VERSION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
PROTOCOL_VERSION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
put(String, String) - Method in class org.apache.arrow.flight.grpc.RequestContextAdapter
 
put(String, String) - Method in interface org.apache.arrow.flight.RequestContext
Register a variable and a value.
put(V) - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Maps the specified key to the specified value.
put(Dictionary) - Method in class org.apache.arrow.vector.dictionary.DictionaryProvider.MapDictionaryProvider
 
put(K, V, boolean) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
put(K, V, boolean) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
Inserts the tuple (key, value) into the map extending the semantics of Map.put(K, V) with automatic ordinal assignment.
put(K, V, boolean) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
Inserts the tuple (key, value) into the multimap with automatic ordinal assignment.
put(K, V, boolean) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
putChild(String, FieldVector) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Inserts the vector with the given name if it does not exist else replaces it with the new value.
putMetadata(ArrowBuf) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Send a pure metadata message without any associated data.
putNext() - Method in interface org.apache.arrow.flight.OutboundStreamListener
Send the current contents of the associated VectorSchemaRoot.
putNext(ArrowBuf) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Send the current contents of the associated VectorSchemaRoot alongside application-defined metadata.
PutResult - Class in org.apache.arrow.flight
A message from the server during a DoPut operation.
putVector(String, FieldVector) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Inserts the input vector into the map if it does not exist.

Q

QUERY_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
QUERY_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
QUERY_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 

R

Range - Class in org.apache.arrow.vector.compare
Wrapper for the parameters of comparing a range of values in two vectors.
Range() - Constructor for class org.apache.arrow.vector.compare.Range
Constructs a new instance.
Range(int, int, int) - Constructor for class org.apache.arrow.vector.compare.Range
Constructs a new instance.
rangeEquals(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
Check range equals.
RangeEqualsVisitor - Class in org.apache.arrow.vector.compare
Visitor to compare a range of values for vectors.
RangeEqualsVisitor(ValueVector, ValueVector) - Constructor for class org.apache.arrow.vector.compare.RangeEqualsVisitor
Constructs a new instance with default type comparator.
RangeEqualsVisitor(ValueVector, ValueVector, BiFunction<ValueVector, ValueVector, Boolean>) - Constructor for class org.apache.arrow.vector.compare.RangeEqualsVisitor
Constructs a new instance.
read() - Method in class org.apache.arrow.flight.SyncPutListener
Get the next message from the server, blocking until it is available.
read(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
read(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
read(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
read(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
read(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
read(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
read(DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
read(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
read(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
read(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
read(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
read(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
read(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
read(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
read(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
read(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
read(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
read(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
read(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
read(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
read(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
read(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
read(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
read(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
read(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
read(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
read(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
read(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
read(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
read(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
read(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
read(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
read(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
read(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
read(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
read(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
read(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
read(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
read(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
read(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
read(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
read(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
read(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
read(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
read(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
read(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
read(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
read(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
read(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
read(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
read(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
read(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
read(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
read(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(int, NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
read(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
read(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
read(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
read(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
read(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
read(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
read(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
read(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
read(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
read(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
read(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
read(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
read(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
read(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
read(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
read(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
read(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
read(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
read(UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
read(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
read(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
read(UnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
read(int, UnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
read(DenseUnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
read(int, DenseUnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
read(BigIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
 
read(NullableBigIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
 
read(BitHolder) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
 
read(NullableBitHolder) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
 
read(DateDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
 
read(NullableDateDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
 
read(DateMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
 
read(NullableDateMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
 
read(Decimal256Holder) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
 
read(NullableDecimal256Holder) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
 
read(DecimalHolder) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
 
read(NullableDecimalHolder) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
 
read(DurationHolder) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
 
read(NullableDurationHolder) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
 
read(FixedSizeBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
 
read(NullableFixedSizeBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
 
read(Float4Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
 
read(NullableFloat4Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
 
read(Float8Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
 
read(NullableFloat8Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
 
read(IntervalDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
 
read(NullableIntervalDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
 
read(IntervalMonthDayNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
 
read(NullableIntervalMonthDayNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
 
read(IntervalYearHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
 
read(NullableIntervalYearHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
 
read(IntHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
 
read(NullableIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
 
read(LargeVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
 
read(NullableLargeVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
 
read(LargeVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
 
read(NullableLargeVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
 
read(SmallIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
 
read(NullableSmallIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
 
read(TimeMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
 
read(NullableTimeMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
 
read(TimeMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
 
read(NullableTimeMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
 
read(TimeNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
 
read(NullableTimeNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
 
read(TimeSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
 
read(NullableTimeSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
 
read(TimeStampMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
 
read(NullableTimeStampMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
 
read(TimeStampMicroTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
 
read(NullableTimeStampMicroTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
 
read(TimeStampMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
 
read(NullableTimeStampMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
 
read(TimeStampMilliTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
 
read(NullableTimeStampMilliTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
 
read(TimeStampNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
 
read(NullableTimeStampNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
 
read(TimeStampNanoTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
 
read(NullableTimeStampNanoTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
 
read(TimeStampSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
 
read(NullableTimeStampSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
 
read(TimeStampSecTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
 
read(NullableTimeStampSecTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
 
read(TinyIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
 
read(NullableTinyIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
 
read(UInt1Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
 
read(NullableUInt1Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
 
read(UInt2Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
 
read(NullableUInt2Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
 
read(UInt4Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
 
read(NullableUInt4Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
 
read(UInt8Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
 
read(NullableUInt8Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
 
read(VarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
 
read(NullableVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
 
read(VarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
 
read(NullableVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
 
read(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Read the value at the given position to the given output buffer.
read(VectorSchemaRoot) - Method in class org.apache.arrow.vector.ipc.JsonFileReader
Reads the next record batch from the file into root.
read() - Method in class org.apache.arrow.vector.ipc.JsonFileReader
Returns the next record batch from the file.
read(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Read the value at the given position to the given output buffer.
read(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.LargeVarCharVector
Read the value at the given position to the given output buffer.
read(ByteBuffer) - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
read(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.VarBinaryVector
Read the value at the given position to the given output buffer.
read(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.VarCharVector
Read the value at the given position to the given output buffer.
readableBytes() - Method in class org.apache.arrow.memory.ArrowBuf
Returns the number of bytes still available to read in this buffer.
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
readBigDecimal(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readBigDecimal() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readBigDecimal() - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
 
readBigDecimal() - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
 
readBoolean() - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
readBoolean() - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
readBoolean() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readBoolean() - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
readBoolean(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readBoolean() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readBoolean() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readBoolean() - Method in interface org.apache.arrow.vector.complex.reader.BitReader
 
readByte() - Method in class org.apache.arrow.memory.ArrowBuf
Read the byte at readerIndex.
readByte() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
readByte(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
readByte() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readByte() - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
 
readByte() - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
readByteArray(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
readByteArray() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
readByteArray() - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
 
readByteArray() - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
 
readByteArray() - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
 
readBytes(byte[]) - Method in class org.apache.arrow.memory.ArrowBuf
Read dst.length bytes at readerIndex into dst byte array
ReadChannel - Class in org.apache.arrow.vector.ipc
Adapter around ReadableByteChannel that reads into ArrowBufs.
ReadChannel(ReadableByteChannel) - Constructor for class org.apache.arrow.vector.ipc.ReadChannel
 
readCharacter() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readCharacter() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
readCharacter(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readCharacter() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readCharacter() - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
readCharacter() - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
readCharacter() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readCharacter() - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
 
readDictionary() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
Read a dictionary batch from the source, will be invoked after the schema has been read and called N times, where N is the number of dictionaries indicated by the schema Fields.
readDouble() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readDouble() - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
readDouble() - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
readDouble() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
readDouble(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readDouble() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readDouble() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readDouble() - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
readDuration(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readDuration() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readDuration() - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
 
readDuration() - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
 
reader(byte, String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
reader(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
reader(String) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
reader() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
reader() - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
 
reader(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
reader() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
reader() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
reader() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
reader(String) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
reader() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
reader - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
reader - Variable in class org.apache.arrow.vector.complex.ListVector
 
reader() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.ListReader
 
reader() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.MapReader
 
reader(String) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.StructReader
 
reader - Variable in class org.apache.arrow.vector.holders.ComplexHolder
 
reader - Variable in class org.apache.arrow.vector.holders.DenseUnionHolder
 
reader - Variable in class org.apache.arrow.vector.holders.UnionHolder
 
readerIndex(int) - Method in class io.netty.buffer.NettyArrowBuf
 
readerIndex() - Method in class org.apache.arrow.memory.ArrowBuf
Get the index at which the next byte will be read from.
readerIndex(long) - Method in class org.apache.arrow.memory.ArrowBuf
Set the reader index for this ArrowBuf.
readFloat() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readFloat() - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
readFloat() - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
readFloat() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
readFloat(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readFloat() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readFloat() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readFloat() - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
 
readFully(ByteBuffer) - Method in class org.apache.arrow.vector.ipc.ReadChannel
Reads bytes into buffer until it is full (buffer.remaining() == 0).
readFully(ArrowBuf, long) - Method in class org.apache.arrow.vector.ipc.ReadChannel
Reads up to len into buffer.
readInteger() - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
readInteger(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
readInteger() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readInteger() - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
 
readInteger() - Method in interface org.apache.arrow.vector.complex.reader.IntReader
 
readInteger() - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
 
readInteger() - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
 
readIntoBuffer(InputStream, ArrowBuf, int, boolean) - Static method in class org.apache.arrow.flight.grpc.GetReadableBuffer
Helper method to read a gRPC-provided InputStream into an ArrowBuf.
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
readLocalDateTime(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
readLocalDateTime() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readLocalDateTime() - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
 
readLocalDateTime() - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
 
readLocalDateTime() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
 
readLocalDateTime() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
 
readLocalDateTime() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
 
readLocalDateTime() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
readLong(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
readLong() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
 
readLong() - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
 
readMessage(ReadChannel) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Read a Message from the input channel and return a MessageMetadataResult that contains the Message metadata, buffer containing the serialized Message metadata as read, and length of the Message in bytes.
readMessageBody(ReadChannel, long, BufferAllocator) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Read a Message body from the in channel into an ArrowBuf.
readNext() - Method in class org.apache.arrow.vector.ipc.message.MessageChannelReader
Read a message from the ReadChannel and return a MessageResult containing the Message metadata and optional message body data.
readObject() - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.BigIntReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.BitReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DateDayReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.Decimal256ReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DecimalReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.DurationReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.Float4ReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.Float8ReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.IntReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
readObject(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
readObject() - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.BitReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.IntReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
 
readObject() - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
 
readPeriod() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readPeriod() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
readPeriod() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearReaderImpl
 
readPeriod() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
readPeriod(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readPeriod() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readPeriod() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readPeriod() - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
 
readPeriodDuration() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readPeriodDuration() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
readPeriodDuration() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoReaderImpl
 
readPeriodDuration() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
readPeriodDuration(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readPeriodDuration() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readPeriodDuration() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readPeriodDuration() - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
 
readSchema() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
 
readSchema() - Method in class org.apache.arrow.vector.ipc.ArrowReader
Read the Schema from the source, will be invoked at the beginning the initialization.
readSchema() - Method in class org.apache.arrow.vector.ipc.ArrowStreamReader
Reads the schema message from the beginning of the stream.
readShort() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readShort() - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
readShort(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readShort() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readShort() - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
readShort() - Method in class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
readShort() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readShort() - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
 
readString(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readString() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readText() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
readText() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
readText() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharReaderImpl
 
readText() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
readText() - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
readText(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readText() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
readText() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
readText() - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
readText() - Method in class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
readText() - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
 
readText() - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
 
readUncompressedLength(ArrowBuf) - Method in class org.apache.arrow.vector.compression.AbstractCompressionCodec
 
readWithKnownLength(DataInput, int) - Method in class org.apache.arrow.vector.util.Text
Read a Text object whose length is already known.
readyCallback() - Method in class org.apache.arrow.flight.BackpressureStrategy.CallbackBackpressureStrategy
Callback to execute when the listener becomes ready.
reAlloc() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Resize the vector to increase the capacity.
reAlloc() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Resize the vector to increase the capacity.
reAlloc() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Resize the vector to increase the capacity.
reAlloc() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
reAlloc() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
reAlloc() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
reAlloc() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
reAlloc() - Method in class org.apache.arrow.vector.complex.LargeListVector
Resize the vector to increase the capacity.
reAlloc() - Method in class org.apache.arrow.vector.complex.ListVector
Resize the vector to increase the capacity.
reAlloc() - Method in class org.apache.arrow.vector.complex.StructVector
 
reAlloc() - Method in class org.apache.arrow.vector.complex.UnionVector
 
reAlloc() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
reAlloc() - Method in class org.apache.arrow.vector.NullVector
 
reAlloc() - Method in interface org.apache.arrow.vector.ValueVector
Allocate new buffer with double capacity, and copy data into the new buffer.
reallocDataBuffer() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Reallocate the data buffer.
reallocDataBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Reallocate the data buffer.
reallocDataBuffer(long) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Reallocate the data buffer to given size.
reallocIfNeeded(long) - Method in class org.apache.arrow.memory.ArrowBuf
Returns this if size is less than ArrowBuf.capacity(), otherwise delegates to BufferManager.replace(ArrowBuf, long) to get a new buffer.
reallocOffsetBuffer() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
reallocOffsetBuffer() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
reallocValidityAndOffsetBuffers() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Reallocate the validity and offset buffers for this vector.
reallocValidityAndOffsetBuffers() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Reallocate the validity and offset buffers for this vector.
reallocValidityAndOffsetBuffers() - Method in class org.apache.arrow.vector.complex.ListVector
 
RECORD_COUNT_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
RecordBatch - Static variable in class org.apache.arrow.flatbuf.MessageHeader
 
RecordBatch - Class in org.apache.arrow.flatbuf
A data header describing the shared memory layout of a "record" or "row" batch.
RecordBatch() - Constructor for class org.apache.arrow.flatbuf.RecordBatch
 
RecordBatch.Vector - Class in org.apache.arrow.flatbuf
 
recordBatches(int) - Method in class org.apache.arrow.flatbuf.Footer
 
recordBatches(Block, int) - Method in class org.apache.arrow.flatbuf.Footer
 
recordBatchesLength() - Method in class org.apache.arrow.flatbuf.Footer
 
recordBatchesVector() - Method in class org.apache.arrow.flatbuf.Footer
 
recordBatchesVector(Block.Vector) - Method in class org.apache.arrow.flatbuf.Footer
 
recordEvent(String, Object...) - Method in class org.apache.arrow.memory.util.HistoricalLog
Record an event.
RECORDS_PER_BATCH_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
RECORDS_PER_STREAM_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
refCnt() - Method in class io.netty.buffer.NettyArrowBuf
 
refCnt() - Method in class org.apache.arrow.memory.ArrowBuf
 
ReferenceManager - Interface in org.apache.arrow.memory
ReferenceManager is the reference count for one or more allocations.
refreshValueCapacity() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Call this if you change the capacity of valueBuffer or validityBuffer.
register(FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.BackpressureStrategy.CallbackBackpressureStrategy
 
register(FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.BackpressureStrategy
Set up operations to work against the given listener.
register(ArrowType.ExtensionType) - Static method in class org.apache.arrow.vector.types.pojo.ExtensionTypeRegistry
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.arrow.flight.impl.Flight
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.arrow.flight.perf.impl.PerfOuterClass
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.Test
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.arrow.flight.Test
 
registerNewTypeId(Field) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
release() - Method in class io.netty.buffer.NettyArrowBuf
 
release(int) - Method in class io.netty.buffer.NettyArrowBuf
 
release() - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
release(FlightSqlClient.Savepoint, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Release a savepoint.
release() - Method in class org.apache.arrow.memory.BufferLedger
Decrement the ledger's reference count by 1 for the associated underlying memory chunk.
release(int) - Method in class org.apache.arrow.memory.BufferLedger
Decrement the ledger's reference count for the associated underlying memory chunk.
release() - Method in interface org.apache.arrow.memory.ReferenceManager
Decrement this reference manager's reference count by 1 for the associated underlying memory.
release(int) - Method in interface org.apache.arrow.memory.ReferenceManager
Decrement this reference manager's reference count for the associated underlying memory.
release0() - Method in class org.apache.arrow.memory.AllocationManager
Release the underlying memory chunk.
release0() - Method in class org.apache.arrow.memory.ForeignAllocation
Free this allocation.
release0() - Method in class org.apache.arrow.memory.NettyAllocationManager
 
release0() - Method in class org.apache.arrow.memory.UnsafeAllocationManager
 
releaseBuffer(ArrowBuf) - Method in class org.apache.arrow.vector.BaseValueVector
 
releaseBytes(long) - Method in interface org.apache.arrow.memory.BufferAllocator
Release bytes from this allocator.
releaseSavepoint(Savepoint) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
remove(String) - Method in class org.apache.arrow.flight.grpc.RequestContextAdapter
 
remove(String) - Method in interface org.apache.arrow.flight.RequestContext
Deletes a registered variable.
remove(K) - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Removes the mapping with the specified key from this map.
remove(K, V) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
remove(K, V) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
remove(K, V) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
Removes the element corresponding to the key/value if exists with ordinal re-cycling.
remove(K, V) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
removeAll(K) - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
removeAll(K) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
Removes the element corresponding to the key if exists extending the semantics of Map.remove(java.lang.Object) with ordinal re-cycling.
removeAll(K) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
remove all entries of key.
removeAll(K) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
removeConnectionEventListener(ConnectionEventListener) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcPooledConnection
 
removeEndpoint(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
removeLocation(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
removeStatementEventListener(StatementEventListener) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcPooledConnection
 
removeVector(int) - Method in class org.apache.arrow.vector.table.Table
Returns a new Table created by removing the selected Vector from this Table.
removeVector(int) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Remove vector from the record batch, producing a new VectorSchemaRoot.
renameFieldVector(String, String) - Method in class org.apache.arrow.driver.jdbc.utils.VectorSchemaRootTransformer.Builder
Add task to transform a vector to a new vector renaming it.
RENEW_FLIGHT_ENDPOINT - Static variable in interface org.apache.arrow.flight.FlightConstants
 
renewFlightEndpoint(RenewFlightEndpointRequest, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Request the server to extend the lifetime of a query result set.
renewFlightEndpoint(RenewFlightEndpointRequest, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Request the server to extend the lifetime of a query result set.
renewFlightEndpoint(RenewFlightEndpointRequest, FlightProducer.CallContext, FlightProducer.StreamListener<FlightEndpoint>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
Renew the duration of the given endpoint.
RenewFlightEndpointRequest - Class in org.apache.arrow.flight
A request to extend the expiration time of a FlightEndpoint.
RenewFlightEndpointRequest(FlightEndpoint) - Constructor for class org.apache.arrow.flight.RenewFlightEndpointRequest
 
RepeatedFixedWidthVectorLike - Interface in org.apache.arrow.vector.complex
A ValueVector mix-in that can be used in conjunction with RepeatedValueVector subtypes.
RepeatedListHolder - Class in org.apache.arrow.vector.holders
ValueHolder for a nested ListVector.
RepeatedListHolder() - Constructor for class org.apache.arrow.vector.holders.RepeatedListHolder
 
RepeatedStructHolder - Class in org.apache.arrow.vector.holders
ValueHolder for a list of structs.
RepeatedStructHolder() - Constructor for class org.apache.arrow.vector.holders.RepeatedStructHolder
 
RepeatedValueComparator(VectorValueComparator<T>) - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.RepeatedValueComparator
 
RepeatedValueVector - Interface in org.apache.arrow.vector.complex
An abstraction representing repeated value vectors.
RepeatedVariableWidthVectorLike - Interface in org.apache.arrow.vector.complex
A ValueVector mix-in that can be used in conjunction with variable RepeatedValueVector subtypes (e.g.
replace(ArrowBuf, long) - Method in interface org.apache.arrow.memory.BufferManager
Replace an old buffer with a new version at least of the provided size.
replaceDataVector(FieldVector) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
replaceDataVector(FieldVector) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
replaceSemiColons(String) - Static method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
Replaces the semicolons in the URL to the proper format.
request(int) - Method in interface org.apache.arrow.flight.FlightStream.Requestor
Requests count more messages from the instance of this object.
REQUEST_CONTEXT_KEY - Static variable in class org.apache.arrow.flight.grpc.RequestContextAdapter
 
RequestContext - Interface in org.apache.arrow.flight
Tracks variables about the current request.
RequestContextAdapter - Class in org.apache.arrow.flight.grpc
Adapter for holding key value pairs.
RequestContextAdapter() - Constructor for class org.apache.arrow.flight.grpc.RequestContextAdapter
 
required() - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
 
reserve(int) - Method in interface org.apache.arrow.memory.AllocationReservation
Requests a reservation of additional space.
reset() - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder
Reset the binder (so the root can be updated with new data).
reset() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Reset the vector to initial state.
reset() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Reset the vector to initial state.
reset() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Reset the vector to initial state.
reset() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
reset() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
reset() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
reset() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
reset() - Method in class org.apache.arrow.vector.complex.LargeListVector
 
reset() - Method in class org.apache.arrow.vector.complex.ListVector
 
reset() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
reset() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
 
reset() - Method in class org.apache.arrow.vector.complex.StructVector
Reset this vector to empty, does not release buffers.
reset() - Method in class org.apache.arrow.vector.complex.UnionVector
 
reset() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
reset() - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
reset() - Method in class org.apache.arrow.vector.NullVector
 
reset() - Method in interface org.apache.arrow.vector.ValueVector
Reset the ValueVector to the initial state without releasing any owned ArrowBuf.
resetConsumerVectors(VectorSchemaRoot) - Method in class org.apache.arrow.consumers.CompositeAvroConsumer
Reset vector of consumers with the given VectorSchemaRoot.
resetPosition() - Method in class org.apache.arrow.vector.table.Row
Resets the current row to -1 and returns this object.
resetValueVector(ListVector) - Method in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
 
resetValueVector(V) - Method in class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
 
resetValueVector(VarBinaryVector) - Method in class org.apache.arrow.adapter.jdbc.consumer.BinaryConsumer
 
resetValueVector(VarBinaryVector) - Method in class org.apache.arrow.adapter.jdbc.consumer.BlobConsumer
 
resetValueVector(VarCharVector) - Method in class org.apache.arrow.adapter.jdbc.consumer.ClobConsumer
 
resetValueVector(ValueVector) - Method in class org.apache.arrow.adapter.jdbc.consumer.CompositeJdbcConsumer
 
resetValueVector(T) - Method in interface org.apache.arrow.adapter.jdbc.consumer.JdbcConsumer
Reset the vector within consumer for partial read purpose.
resetValueVector(ListVector) - Method in class org.apache.arrow.consumers.AvroArraysConsumer
 
resetValueVector(MapVector) - Method in class org.apache.arrow.consumers.AvroMapConsumer
 
resetValueVector(StructVector) - Method in class org.apache.arrow.consumers.AvroStructConsumer
 
resetValueVector(UnionVector) - Method in class org.apache.arrow.consumers.AvroUnionsConsumer
 
resetValueVector(T) - Method in class org.apache.arrow.consumers.BaseAvroConsumer
 
resetValueVector(T) - Method in interface org.apache.arrow.consumers.Consumer
Reset the vector within consumer for partial read purpose.
resetValueVector(FieldVector) - Method in class org.apache.arrow.consumers.SkipConsumer
 
resetVectorSchemaRoot(VectorSchemaRoot) - Method in class org.apache.arrow.adapter.jdbc.consumer.CompositeJdbcConsumer
Reset inner consumers through vectors in the vector schema root.
RESTRICT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
RESTRICT = 1;
Result - Class in org.apache.arrow.flight
Opaque result returned after executing an action.
Result(byte[]) - Constructor for class org.apache.arrow.flight.Result
 
RESULT_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
retain() - Method in class io.netty.buffer.NettyArrowBuf
 
retain(int) - Method in class io.netty.buffer.NettyArrowBuf
 
retain() - Method in class org.apache.arrow.memory.BufferLedger
Increment the ledger's reference count for associated underlying memory chunk by 1.
retain(int) - Method in class org.apache.arrow.memory.BufferLedger
Increment the ledger's reference count for associated underlying memory chunk by the given amount.
retain(ArrowBuf, BufferAllocator) - Method in class org.apache.arrow.memory.BufferLedger
Create a new ArrowBuf that is associated with an alternative allocator for the purposes of memory ownership and accounting.
retain() - Method in interface org.apache.arrow.memory.ReferenceManager
Increment this reference manager's reference count by 1 for the associated underlying memory.
retain(int) - Method in interface org.apache.arrow.memory.ReferenceManager
Increment this reference manager's reference count by a given amount for the associated underlying memory.
retain(ArrowBuf, BufferAllocator) - Method in interface org.apache.arrow.memory.ReferenceManager
Create a new ArrowBuf that is associated with an alternative allocator for the purposes of memory ownership and accounting.
retainAuth() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Indicates if sub-connections created for stream retrieval should reuse bearer tokens created from the main connection.
retainCookies() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Indicates if sub-connections created for stream retrieval should reuse cookies from the main connection.
ReusableBuffer<T> - Interface in org.apache.arrow.memory
A lightweight, automatically expanding container for holding byte data.
ReusableByteArray - Class in org.apache.arrow.vector.util
A wrapper around byte arrays for repeated writing.
ReusableByteArray() - Constructor for class org.apache.arrow.vector.util.ReusableByteArray
 
ReusableByteArray(byte[]) - Constructor for class org.apache.arrow.vector.util.ReusableByteArray
 
rollback(Meta.ConnectionHandle) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
rollback() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
rollback(Savepoint) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
rollback(FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Rollback a transaction.
rollback(FlightSqlClient.Savepoint, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
Rollback to a savepoint.
rollbackable(AutoCloseable...) - Static method in class org.apache.arrow.util.AutoCloseables
Creates an AutoCloseables.RollbackCloseable from the given closeables.
RollbackCloseable(AutoCloseable...) - Constructor for class org.apache.arrow.util.AutoCloseables.RollbackCloseable
 
RootAllocator - Class in org.apache.arrow.memory
A root allocator for using direct memory for Arrow Vectors/Arrays.
RootAllocator() - Constructor for class org.apache.arrow.memory.RootAllocator
 
RootAllocator(long) - Constructor for class org.apache.arrow.memory.RootAllocator
 
RootAllocator(AllocationListener, long) - Constructor for class org.apache.arrow.memory.RootAllocator
 
RootAllocator(AllocationListener, long, RoundingPolicy) - Constructor for class org.apache.arrow.memory.RootAllocator
Constructor.
RootAllocator(BaseAllocator.Config) - Constructor for class org.apache.arrow.memory.RootAllocator
 
rootAsList() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
rootAsList() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.ComplexReader
 
rootAsList() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
rootAsMap(boolean) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
rootAsMap(boolean) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
rootAsStruct() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
rootAsStruct() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.ComplexReader
 
rootAsStruct() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
rootIsStruct() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.ComplexReader
 
ROUND_8_MASK_INT - Static variable in class org.apache.arrow.vector.util.DataSizeRoundingUtil
The mask for rounding an integer to a multiple of 8.
ROUND_8_MASK_LONG - Static variable in class org.apache.arrow.vector.util.DataSizeRoundingUtil
The mask for rounding a long integer to a multiple of 8.
roundDownTo8Multiple(int) - Static method in class org.apache.arrow.vector.util.DataSizeRoundingUtil
Round down the number to the nearest multiple of 8.
roundDownTo8Multiple(long) - Static method in class org.apache.arrow.vector.util.DataSizeRoundingUtil
Round down the number to the nearest multiple of 8.
RoundingPolicy - Interface in org.apache.arrow.memory.rounding
The policy for rounding the buffer size, to improve performance and avoid memory fragmentation.
roundUpTo8Multiple(int) - Static method in class org.apache.arrow.vector.util.DataSizeRoundingUtil
Round up the number to the nearest multiple of 8.
roundUpTo8Multiple(long) - Static method in class org.apache.arrow.vector.util.DataSizeRoundingUtil
Round up the number to the nearest multiple of 8.
Row - Static variable in class org.apache.arrow.flatbuf.SparseMatrixCompressedAxis
 
Row - Class in org.apache.arrow.vector.table
Row is a positionable, immutable cursor backed by a Table.
Row(BaseTable) - Constructor for class org.apache.arrow.vector.table.Row
Constructs a new Row backed by the given table.
rowCount - Variable in class org.apache.arrow.vector.table.BaseTable
The number of rows of data in the table; not necessarily the same as the table row capacity.
rowNumber - Variable in class org.apache.arrow.vector.table.Row
the current row number.
run() - Method in class org.apache.arrow.tools.EchoServer.ClientConnection
Reads a record batch off the socket and writes it back out.
run() - Method in class org.apache.arrow.tools.EchoServer
Starts the main server event loop.
RunEndEncoded - Class in org.apache.arrow.flatbuf
Contains two child arrays, run_ends and values.
RunEndEncoded() - Constructor for class org.apache.arrow.flatbuf.RunEndEncoded
 
RunEndEncoded - Static variable in class org.apache.arrow.flatbuf.Type
 
RunEndEncoded.Vector - Class in org.apache.arrow.flatbuf
 

S

Savepoint(byte[]) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.Savepoint
 
SAVEPOINT_ID - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
SAVEPOINT_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
SAVEPOINT_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
SAVEPOINT_NAME - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
scale() - Method in class org.apache.arrow.flatbuf.Decimal
Number of digits after the decimal point "."
scale(int) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets the scale / decimal digits.
scale - Variable in class org.apache.arrow.vector.holders.Decimal256Holder
 
scale - Variable in class org.apache.arrow.vector.holders.DecimalHolder
 
scale - Variable in class org.apache.arrow.vector.holders.NullableDecimal256Holder
 
scale - Variable in class org.apache.arrow.vector.holders.NullableDecimalHolder
 
schema() - Method in class org.apache.arrow.flatbuf.Footer
 
schema(Schema) - Method in class org.apache.arrow.flatbuf.Footer
 
Schema - Static variable in class org.apache.arrow.flatbuf.MessageHeader
 
Schema - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- A Schema describes the columns in a row batch
Schema() - Constructor for class org.apache.arrow.flatbuf.Schema
 
schema - Variable in class org.apache.arrow.vector.ipc.ArrowWriter
 
schema - Variable in class org.apache.arrow.vector.table.BaseTable
The schema for the table.
Schema - Class in org.apache.arrow.vector.types.pojo
An Arrow Schema.
Schema(Iterable<Field>) - Constructor for class org.apache.arrow.vector.types.pojo.Schema
 
Schema(Iterable<Field>, Map<String, String>) - Constructor for class org.apache.arrow.vector.types.pojo.Schema
Constructor with metadata.
Schema.Vector - Class in org.apache.arrow.flatbuf
 
SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
SCHEMA_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
SchemaChangeCallBack - Class in org.apache.arrow.vector
Callback for when the Schema for the Vector changes (generally happens when a vector is promoted to a union type from a single value type).
SchemaChangeCallBack() - Constructor for class org.apache.arrow.vector.SchemaChangeCallBack
Constructs a schema-change callback with the schema-changed state set to false.
SchemaChangeRuntimeException - Exception in org.apache.arrow.vector.util
Thrown when child vectors (e.g.
SchemaChangeRuntimeException() - Constructor for exception org.apache.arrow.vector.util.SchemaChangeRuntimeException
 
SchemaChangeRuntimeException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.arrow.vector.util.SchemaChangeRuntimeException
 
SchemaChangeRuntimeException(String, Throwable) - Constructor for exception org.apache.arrow.vector.util.SchemaChangeRuntimeException
 
SchemaChangeRuntimeException(String) - Constructor for exception org.apache.arrow.vector.util.SchemaChangeRuntimeException
 
SchemaChangeRuntimeException(Throwable) - Constructor for exception org.apache.arrow.vector.util.SchemaChangeRuntimeException
 
schemaName(String) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets the schema name.
SchemaResult - Class in org.apache.arrow.flight
Opaque result returned after executing a getSchema request.
SchemaResult(Schema) - Constructor for class org.apache.arrow.flight.SchemaResult
 
SchemaResult(Schema, IpcOption) - Constructor for class org.apache.arrow.flight.SchemaResult
Create a schema result with specific IPC options for serialization.
SchemaUtility - Class in org.apache.arrow.vector.util
Schema utility class including serialization and deserialization.
search(V, int) - Method in class org.apache.arrow.algorithm.search.ParallelSearcher
Search for the key in the target vector.
search(V, int, VectorValueComparator<V>) - Method in class org.apache.arrow.algorithm.search.ParallelSearcher
Search for the key in the target vector.
SEARCH_FAIL_RESULT - Static variable in class org.apache.arrow.algorithm.search.VectorRangeSearcher
Result returned when a search fails.
SEARCH_FAIL_RESULT - Static variable in class org.apache.arrow.algorithm.search.VectorSearcher
Result returned when a search fails.
SEARCHABLE_BASIC_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
Indicates that the column can be used In a WHERE clause with any operator other than LIKE.
SEARCHABLE_CHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
Indicates that the column can be used in a WHERE clause if it is using a LIKE operator.
SEARCHABLE_FULL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
Indicates that the column can be used in a WHERE clause using any operator.
SEARCHABLE_NONE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
Indicates that column cannot be used in a WHERE clause.
SearchDictionaryEncoder<E extends BaseIntVector,D extends ValueVector> - Class in org.apache.arrow.algorithm.dictionary
Dictionary encoder based on searching.
SearchDictionaryEncoder(D, VectorValueComparator<D>) - Constructor for class org.apache.arrow.algorithm.dictionary.SearchDictionaryEncoder
Constructs a dictionary encoder.
SearchDictionaryEncoder(D, VectorValueComparator<D>, boolean) - Constructor for class org.apache.arrow.algorithm.dictionary.SearchDictionaryEncoder
Constructs a dictionary encoder.
SearchTreeBasedDictionaryBuilder<V extends ValueVector> - Class in org.apache.arrow.algorithm.dictionary
This class builds the dictionary based on a binary search tree.
SearchTreeBasedDictionaryBuilder(V, VectorValueComparator<V>) - Constructor for class org.apache.arrow.algorithm.dictionary.SearchTreeBasedDictionaryBuilder
Construct a search tree-based dictionary builder.
SearchTreeBasedDictionaryBuilder(V, VectorValueComparator<V>, boolean) - Constructor for class org.apache.arrow.algorithm.dictionary.SearchTreeBasedDictionaryBuilder
Construct a search tree-based dictionary builder.
SECOND - Static variable in class org.apache.arrow.flatbuf.TimeUnit
 
secondsToMillis - Static variable in class org.apache.arrow.vector.util.DateUtility
 
SeekableReadChannel - Class in org.apache.arrow.vector.ipc
An ReadChannel that supports seeking to a random position.
SeekableReadChannel(SeekableByteChannel) - Constructor for class org.apache.arrow.vector.ipc.SeekableReadChannel
 
SegmentRoundingPolicy - Class in org.apache.arrow.memory.rounding
The rounding policy that each buffer size must a multiple of the segment size.
SegmentRoundingPolicy(int) - Constructor for class org.apache.arrow.memory.rounding.SegmentRoundingPolicy
Constructor for the segment rounding policy.
send(byte[]) - Method in interface org.apache.arrow.flight.auth.ClientAuthHandler.ClientAuthSender
Deprecated.
Send the server a message.
send(byte[]) - Method in interface org.apache.arrow.flight.auth.ServerAuthHandler.ServerAuthSender
Deprecated.
 
send(List<Integer>, FlightProducer.ServerStreamListener) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Send the requested information to given ServerStreamListener.
serialize() - Method in class org.apache.arrow.flight.CancelFlightInfoRequest
Get the serialized form of this protocol message.
serialize() - Method in class org.apache.arrow.flight.CancelFlightInfoResult
Get the serialized form of this protocol message.
serialize() - Method in class org.apache.arrow.flight.FlightDescriptor
Get the serialized form of this protocol message.
serialize() - Method in class org.apache.arrow.flight.FlightEndpoint
Get the serialized form of this protocol message.
serialize() - Method in class org.apache.arrow.flight.FlightInfo
Get the serialized form of this protocol message.
serialize() - Method in class org.apache.arrow.flight.PollInfo
 
serialize() - Method in class org.apache.arrow.flight.RenewFlightEndpointRequest
Get the serialized form of this protocol message.
serialize() - Method in class org.apache.arrow.flight.Ticket
Get the serialized form of this protocol message.
serialize(WriteChannel, Schema) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Serialize a schema object.
serialize(WriteChannel, Schema, IpcOption) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Serialize a schema object.
serialize(WriteChannel, ArrowRecordBatch) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Serializes an ArrowRecordBatch.
serialize(WriteChannel, ArrowRecordBatch, IpcOption) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Serializes an ArrowRecordBatch.
serialize(WriteChannel, ArrowDictionaryBatch) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
 
serialize(WriteChannel, ArrowDictionaryBatch, IpcOption) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Serializes a dictionary ArrowRecordBatch.
serialize(FBSerializable) - Static method in class org.apache.arrow.vector.ipc.WriteChannel
Serializes writer to a ByteBuffer.
serialize() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
Save any metadata for this type.
serialize(Schema) - Static method in class org.apache.arrow.vector.util.SchemaUtility
Serialize Arrow schema into byte array.
serialize(Text, JsonGenerator, SerializerProvider) - Method in class org.apache.arrow.vector.util.Text.TextSerializer
 
serializeAsMessage() - Method in class org.apache.arrow.vector.types.pojo.Schema
Returns the serialized flatbuffer bytes of the schema wrapped in a message table.
serializeMessage(FlatBufferBuilder, byte, int, long) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deprecated.
serializeMessage(FlatBufferBuilder, byte, int, long, IpcOption) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Serializes a message header.
serializeMetadata(Schema) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deprecated.
serializeMetadata(Schema, IpcOption) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Returns the serialized flatbuffer bytes of the schema wrapped in a message table.
serializeMetadata(ArrowMessage) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Deprecated.
serializeMetadata(ArrowMessage, IpcOption) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Returns the serialized form of RecordBatch wrapped in a Message.
SERVER_MIDDLEWARE_KEY - Static variable in class org.apache.arrow.flight.grpc.ServerInterceptorAdapter
The Context.Key that stores the Flight middleware active for a particular call.
ServerAuthHandler - Interface in org.apache.arrow.flight.auth
Deprecated.
As of 14.0.0. This implements a stateful "login" flow that does not play well with distributed or stateless systems. It will not be removed, but should not be used. Instead, see FlightServer.Builder#headerAuthenticator(CallHeaderAuthenticator) and CallHeaderAuthenticator.
ServerAuthHandler.ServerAuthSender - Interface in org.apache.arrow.flight.auth
Deprecated.
Interface for a server implementations to send back authentication messages back to the client.
ServerAuthInterceptor - Class in org.apache.arrow.flight.auth
GRPC Interceptor for performing authentication.
ServerAuthInterceptor(ServerAuthHandler) - Constructor for class org.apache.arrow.flight.auth.ServerAuthInterceptor
 
ServerAuthWrapper - Class in org.apache.arrow.flight.auth
Contains utility methods for integrating authorization into a GRPC stream.
ServerAuthWrapper() - Constructor for class org.apache.arrow.flight.auth.ServerAuthWrapper
 
ServerCallHeaderAuthMiddleware - Class in org.apache.arrow.flight.auth2
Middleware that's used to validate credentials during the handshake and verify the bearer token in subsequent requests.
ServerCallHeaderAuthMiddleware(CallHeaderAuthenticator.AuthResult) - Constructor for class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware
 
ServerCallHeaderAuthMiddleware.Factory - Class in org.apache.arrow.flight.auth2
Factory for accessing ServerAuthMiddleware.
ServerHeaderMiddleware - Class in org.apache.arrow.flight
Middleware that's used to extract and pass headers to the server during requests.
ServerHeaderMiddleware.Factory - Class in org.apache.arrow.flight
Factory for accessing ServerHeaderMiddleware.
ServerInterceptorAdapter - Class in org.apache.arrow.flight.grpc
An adapter between Flight middleware and a gRPC interceptor.
ServerInterceptorAdapter(List<ServerInterceptorAdapter.KeyFactory<?>>) - Constructor for class org.apache.arrow.flight.grpc.ServerInterceptorAdapter
 
ServerInterceptorAdapter.KeyFactory<T extends FlightServerMiddleware> - Class in org.apache.arrow.flight.grpc
A combination of a middleware Key and factory.
SERVICE - Static variable in interface org.apache.arrow.flight.FlightConstants
 
SERVICE_NAME - Static variable in class org.apache.arrow.flight.impl.FlightServiceGrpc
 
SERVICE_NAME - Static variable in class org.apache.arrow.flight.TestServiceGrpc
 
set(BigDecimal) - Method in class org.apache.arrow.adapter.jdbc.consumer.Decimal256Consumer
 
set(BigDecimal) - Method in class org.apache.arrow.adapter.jdbc.consumer.DecimalConsumer
 
set(ArrowBuf, long, long) - Method in interface org.apache.arrow.memory.ReusableBuffer
Set the buffer to the contents of the given ArrowBuf.
set(ArrowBuf, long, long) - Method in class org.apache.arrow.memory.util.ArrowBufPointer
Sets this pointer.
set(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
set(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
set(int, byte[]) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Set the variable length element at the specified index to the supplied byte array.
set(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Set the variable length element at the specified index to the supplied byte array.
set(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Set the variable length element at the specified index to the content in supplied ByteBuffer.
set(int, int, long, long, ArrowBuf) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Store the given value at a particular position in the vector.
set(int, long, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Store the given value at a particular position in the vector.
set(ArrowBuf, BufferAllocator, int, int, long) - Static method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Method used by Json Reader to explicitly set the offsets of the variable width vector data.
set(int, byte[]) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Set the variable length element at the specified index to the supplied byte array.
set(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Set the variable length element at the specified index to the supplied byte array.
set(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Set the variable length element at the specified index to the content in supplied ByteBuffer.
set(int, int, int, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Store the given value at a particular position in the vector.
set(int, int, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Store the given value at a particular position in the vector.
set(ArrowBuf, BufferAllocator, int, int, int) - Static method in class org.apache.arrow.vector.BaseVariableWidthVector
Method used by Json Reader to explicitly set the offsets of the variable width vector data.
set(int, long) - Method in class org.apache.arrow.vector.BigIntVector
Set the element at the given index to the given value.
set(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.BigIntVector
Set the element at the given index to the value set in data holder.
set(int, BigIntHolder) - Method in class org.apache.arrow.vector.BigIntVector
Set the element at the given index to the value set in data holder.
set(int, int, long) - Method in class org.apache.arrow.vector.BigIntVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.BitVector
Set the element at the given index to the given value.
set(int, NullableBitHolder) - Method in class org.apache.arrow.vector.BitVector
Set the element at the given index to the value set in data holder.
set(int, BitHolder) - Method in class org.apache.arrow.vector.BitVector
Set the element at the given index to the value set in data holder.
set(int, int, int) - Method in class org.apache.arrow.vector.BitVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.DateDayVector
Set the element at the given index to the given value.
set(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.DateDayVector
Set the element at the given index to the value set in data holder.
set(int, DateDayHolder) - Method in class org.apache.arrow.vector.DateDayVector
Set the element at the given index to the value set in data holder.
set(int, int, int) - Method in class org.apache.arrow.vector.DateDayVector
Store the given value at a particular position in the vector.
set(int, long) - Method in class org.apache.arrow.vector.DateMilliVector
Set the element at the given index to the given value.
set(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.DateMilliVector
Set the element at the given index to the value set in data holder.
set(int, DateMilliHolder) - Method in class org.apache.arrow.vector.DateMilliVector
Set the element at the given index to the value set in data holder.
set(int, int, long) - Method in class org.apache.arrow.vector.DateMilliVector
Store the given value at a particular position in the vector.
set(int, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
Set the element at the given index to the given value.
set(int, long, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
Set the element at the given index to the given value.
set(int, BigDecimal) - Method in class org.apache.arrow.vector.Decimal256Vector
Set the element at the given index to the given value.
set(int, long) - Method in class org.apache.arrow.vector.Decimal256Vector
Set the element at the given index to the given value.
set(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.Decimal256Vector
Set the element at the given index to the value set in data holder.
set(int, Decimal256Holder) - Method in class org.apache.arrow.vector.Decimal256Vector
Set the element at the given index to the value set in data holder.
set(int, int, long, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
Store the given value at a particular position in the vector.
set(int, ArrowBuf) - Method in class org.apache.arrow.vector.DecimalVector
Set the element at the given index to the given value.
set(int, long, ArrowBuf) - Method in class org.apache.arrow.vector.DecimalVector
Set the element at the given index to the given value.
set(int, BigDecimal) - Method in class org.apache.arrow.vector.DecimalVector
Set the element at the given index to the given value.
set(int, long) - Method in class org.apache.arrow.vector.DecimalVector
Set the element at the given index to the given value.
set(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.DecimalVector
Set the element at the given index to the value set in data holder.
set(int, DecimalHolder) - Method in class org.apache.arrow.vector.DecimalVector
Set the element at the given index to the value set in data holder.
set(int, int, long, ArrowBuf) - Method in class org.apache.arrow.vector.DecimalVector
Store the given value at a particular position in the vector.
set(int, ArrowBuf) - Method in class org.apache.arrow.vector.DurationVector
Set the element at the given index to the given value.
set(int, long) - Method in class org.apache.arrow.vector.DurationVector
Set the element at the given index to the given value.
set(int, NullableDurationHolder) - Method in class org.apache.arrow.vector.DurationVector
Set the element at the given index to the value set in data holder.
set(int, DurationHolder) - Method in class org.apache.arrow.vector.DurationVector
Set the element at the given index to the value set in data holder.
set(int, int, long) - Method in class org.apache.arrow.vector.DurationVector
Store the given value at a particular position in the vector.
set(int, byte[]) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Sets the value at index to the provided one.
set(int, int, byte[]) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Sets the value if isSet is positive, otherwise sets the index to null/invalid.
set(int, ArrowBuf) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Set the element at the given index to the given value.
set(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Set the element at the given index to the given value.
set(int, FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, float) - Method in class org.apache.arrow.vector.Float4Vector
Set the element at the given index to the given value.
set(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.Float4Vector
Set the element at the given index to the value set in data holder.
set(int, Float4Holder) - Method in class org.apache.arrow.vector.Float4Vector
Set the element at the given index to the value set in data holder.
set(int, int, float) - Method in class org.apache.arrow.vector.Float4Vector
Store the given value at a particular position in the vector.
set(int, double) - Method in class org.apache.arrow.vector.Float8Vector
Set the element at the given index to the given value.
set(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.Float8Vector
Set the element at the given index to the value set in data holder.
set(int, Float8Holder) - Method in class org.apache.arrow.vector.Float8Vector
Set the element at the given index to the value set in data holder.
set(int, int, double) - Method in class org.apache.arrow.vector.Float8Vector
Store the given value at a particular position in the vector.
set(int, ArrowBuf) - Method in class org.apache.arrow.vector.IntervalDayVector
Set the element at the given index to the given value.
set(int, int, int) - Method in class org.apache.arrow.vector.IntervalDayVector
Set the element at the given index to the given value.
set(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.IntervalDayVector
Set the element at the given index to the value set in data holder.
set(int, IntervalDayHolder) - Method in class org.apache.arrow.vector.IntervalDayVector
Set the element at the given index to the value set in data holder.
set(int, int, int, int) - Method in class org.apache.arrow.vector.IntervalDayVector
Store the given value at a particular position in the vector.
set(int, ArrowBuf) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Set the element at the given index to the given value.
set(int, int, int, long) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Set the element at the given index to the given value.
set(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Set the element at the given index to the value set in data holder.
set(int, IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Set the element at the given index to the value set in data holder.
set(int, int, int, int, long) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.IntervalYearVector
Set the element at the given index to the given value.
set(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.IntervalYearVector
Set the element at the given index to the value set in data holder.
set(int, IntervalYearHolder) - Method in class org.apache.arrow.vector.IntervalYearVector
Set the element at the given index to the value set in data holder.
set(int, int, int) - Method in class org.apache.arrow.vector.IntervalYearVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.IntVector
Set the element at the given index to the given value.
set(int, NullableIntHolder) - Method in class org.apache.arrow.vector.IntVector
Set the element at the given index to the value set in data holder.
set(int, IntHolder) - Method in class org.apache.arrow.vector.IntVector
Set the element at the given index to the value set in data holder.
set(int, int, int) - Method in class org.apache.arrow.vector.IntVector
Store the given value at a particular position in the vector.
set(int, LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, LargeVarCharHolder) - Method in class org.apache.arrow.vector.LargeVarCharVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.LargeVarCharVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, Text) - Method in class org.apache.arrow.vector.LargeVarCharVector
Set the variable length element at the specified index to the content in supplied Text.
set(int, int) - Method in class org.apache.arrow.vector.SmallIntVector
Set the element at the given index to the given value.
set(int, short) - Method in class org.apache.arrow.vector.SmallIntVector
Set the element at the given index to the given value.
set(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.SmallIntVector
Set the element at the given index to the value set in data holder.
set(int, SmallIntHolder) - Method in class org.apache.arrow.vector.SmallIntVector
Set the element at the given index to the value set in data holder.
set(int, int, short) - Method in class org.apache.arrow.vector.SmallIntVector
Store the given value at a particular position in the vector.
set(int, long) - Method in class org.apache.arrow.vector.TimeMicroVector
Set the element at the given index to the given value.
set(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.TimeMicroVector
Set the element at the given index to the value set in data holder.
set(int, TimeMicroHolder) - Method in class org.apache.arrow.vector.TimeMicroVector
Set the element at the given index to the value set in data holder.
set(int, int, long) - Method in class org.apache.arrow.vector.TimeMicroVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.TimeMilliVector
Set the element at the given index to the given value.
set(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.TimeMilliVector
Set the element at the given index to the value set in data holder.
set(int, TimeMilliHolder) - Method in class org.apache.arrow.vector.TimeMilliVector
Set the element at the given index to the value set in data holder.
set(int, int, int) - Method in class org.apache.arrow.vector.TimeMilliVector
Store the given value at a particular position in the vector.
set(int, long) - Method in class org.apache.arrow.vector.TimeNanoVector
Set the element at the given index to the given value.
set(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.TimeNanoVector
Set the element at the given index to the value set in data holder.
set(int, TimeNanoHolder) - Method in class org.apache.arrow.vector.TimeNanoVector
Set the element at the given index to the value set in data holder.
set(int, int, long) - Method in class org.apache.arrow.vector.TimeNanoVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.TimeSecVector
Set the element at the given index to the given value.
set(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.TimeSecVector
Set the element at the given index to the value set in data holder.
set(int, TimeSecHolder) - Method in class org.apache.arrow.vector.TimeSecVector
Set the element at the given index to the value set in data holder.
set(int, int, int) - Method in class org.apache.arrow.vector.TimeSecVector
Store the given value at a particular position in the vector.
set(int, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Set the element at the given index to the value set in data holder.
set(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampMicroHolder) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Set the element at the given index to the value set in data holder.
set(int, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Set the element at the given index to the value set in data holder.
set(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampMilliHolder) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Set the element at the given index to the value set in data holder.
set(int, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Set the element at the given index to the value set in data holder.
set(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampNanoHolder) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Set the element at the given index to the value set in data holder.
set(int, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Set the element at the given index to the value set in data holder.
set(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.TimeStampSecVector
Set the element at the given index to the value set in data holder.
set(int, TimeStampSecHolder) - Method in class org.apache.arrow.vector.TimeStampSecVector
Set the element at the given index to the value set in data holder.
set(int, long) - Method in class org.apache.arrow.vector.TimeStampVector
Set the element at the given index to the given value.
set(int, int, long) - Method in class org.apache.arrow.vector.TimeStampVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.TinyIntVector
Set the element at the given index to the given value.
set(int, byte) - Method in class org.apache.arrow.vector.TinyIntVector
Set the element at the given index to the given value.
set(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.TinyIntVector
Set the element at the given index to the value set in data holder.
set(int, TinyIntHolder) - Method in class org.apache.arrow.vector.TinyIntVector
Set the element at the given index to the value set in data holder.
set(int, int, byte) - Method in class org.apache.arrow.vector.TinyIntVector
Store the given value at a particular position in the vector.
set(int, int) - Method in class org.apache.arrow.vector.UInt1Vector
Set the element at the given index to the given value.
set(int, byte) - Method in class org.apache.arrow.vector.UInt1Vector
Set the element at the given index to the given value.
set(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.UInt1Vector
Set the element at the given index to the value set in data holder.
set(int, UInt1Holder) - Method in class org.apache.arrow.vector.UInt1Vector
Set the element at the given index to the value set in data holder.
set(int, int, byte) - Method in class org.apache.arrow.vector.UInt1Vector
Sets the value at index to value isSet > 0, otherwise sets the index position to invalid/null.
set(int, int) - Method in class org.apache.arrow.vector.UInt2Vector
Set the element at the given index to the given value.
set(int, char) - Method in class org.apache.arrow.vector.UInt2Vector
Set the element at the given index to the given value.
set(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.UInt2Vector
Set the element at the given index to the value set in data holder.
set(int, UInt2Holder) - Method in class org.apache.arrow.vector.UInt2Vector
Set the element at the given index to the value set in data holder.
set(int, int, char) - Method in class org.apache.arrow.vector.UInt2Vector
Sets the given index to value is isSet is positive, otherwise sets the position as invalid/null.
set(int, int) - Method in class org.apache.arrow.vector.UInt4Vector
Set the element at the given index to the given value.
set(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.UInt4Vector
Set the element at the given index to the value set in data holder.
set(int, UInt4Holder) - Method in class org.apache.arrow.vector.UInt4Vector
Set the element at the given index to the value set in data holder.
set(int, int, int) - Method in class org.apache.arrow.vector.UInt4Vector
Sets the value at index to value isSet > 0, otherwise sets the index position to invalid/null.
set(int, long) - Method in class org.apache.arrow.vector.UInt8Vector
Set the element at the given index to the given value.
set(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.UInt8Vector
Set the element at the given index to the value set in data holder.
set(int, UInt8Holder) - Method in class org.apache.arrow.vector.UInt8Vector
Set the element at the given index to the value set in data holder.
set(int, int, long) - Method in class org.apache.arrow.vector.UInt8Vector
Sets value at index is isSet is positive otherwise sets the index to invalid/null.
set(ArrowBuf, long, long) - Method in class org.apache.arrow.vector.util.ReusableByteArray
 
set(String) - Method in class org.apache.arrow.vector.util.Text
Set to contain the contents of a string.
set(byte[]) - Method in class org.apache.arrow.vector.util.Text
Set to a utf8 byte array.
set(Text) - Method in class org.apache.arrow.vector.util.Text
copy a text.
set(byte[], int, int) - Method in class org.apache.arrow.vector.util.Text
Set the Text to range of bytes.
set(int, VarBinaryHolder) - Method in class org.apache.arrow.vector.VarBinaryVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.VarBinaryVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, VarCharHolder) - Method in class org.apache.arrow.vector.VarCharVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.VarCharVector
Set the variable length element at the specified index to the data buffer supplied in the holder.
set(int, Text) - Method in class org.apache.arrow.vector.VarCharVector
Set the variable length element at the specified index to the content in supplied Text.
SET_DEFAULT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
SET_DEFAULT = 4;
SET_NULL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
SET_NULL = 2;
setAction(FlightSql.ActionEndSavepointRequest.EndSavepoint) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Whether to rollback/release the given savepoint.
setAction(FlightSql.ActionEndTransactionRequest.EndTransaction) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Whether to commit/rollback the given transaction.
setActionValue(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Whether to rollback/release the given savepoint.
setActionValue(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Whether to commit/rollback the given transaction.
setAddVectorAsNullable(boolean) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
setAllocator(BufferAllocator) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Sets the memory allocator to use when constructing the Arrow vectors from the ResultSet.
setAppMetadata(byte[]) - Method in class org.apache.arrow.flight.FlightEndpoint.Builder
Set the app metadata to send along with the flight.
setAppMetadata(byte[]) - Method in class org.apache.arrow.flight.FlightInfo.Builder
Set the app metadata to send along with the flight.
setAppMetadata(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
Application-defined metadata.
setAppMetadata(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Application-defined metadata.
setAppMetadata(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
Application-defined metadata.
setAppMetadata(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
bytes app_metadata = 1;
setArraySubTypeByColumnIndexMap(Map<Integer, JdbcFieldInfo>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Sets the mapping of column-index-to-JdbcFieldInfo used for columns of type Types.ARRAY.
setArraySubTypeByColumnNameMap(Map<String, JdbcFieldInfo>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Sets the mapping of column-name-to-JdbcFieldInfo used for columns of type Types.ARRAY.
setAuthHandler(ClientAuthHandler) - Method in class org.apache.arrow.flight.auth.ClientAuthInterceptor
 
setAutoCommit(boolean) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setBigDecimalRoundingMode(RoundingMode) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Set the rounding mode used when the scale of the actual value does not match the declared scale.
setBigEndian(int, byte[]) - Method in class org.apache.arrow.vector.Decimal256Vector
Set the decimal element at given index to the provided array of bytes.
setBigEndian(int, byte[]) - Method in class org.apache.arrow.vector.DecimalVector
Set the decimal element at given index to the provided array of bytes.
setBigEndianSafe(int, long, ArrowBuf, int) - Method in class org.apache.arrow.vector.Decimal256Vector
Sets the element at given index using the buffer whose size maybe <= 32 bytes.
setBigEndianSafe(int, byte[]) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as Decimal256Vector.setBigEndian(int, byte[]) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setBigEndianSafe(int, long, ArrowBuf, int) - Method in class org.apache.arrow.vector.DecimalVector
Sets the element at given index using the buffer whose size maybe <= 16 bytes.
setBigEndianSafe(int, byte[]) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.setBigEndian(int, byte[]) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setBit(ArrowBuf, long) - Static method in class org.apache.arrow.vector.BitVectorHelper
Set the bit at provided index to 1.
setBody(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
bytes body = 2;
setBody(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
bytes body = 1;
setByte(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setByte(int, int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setByte(long, int) - Method in class org.apache.arrow.memory.ArrowBuf
Set byte value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setByte(long, byte) - Method in class org.apache.arrow.memory.ArrowBuf
Set byte value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.NettyArrowBuf
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setBytes(long) - Method in class org.apache.arrow.flight.FlightInfo.Builder
Set the number of bytes for the flight.
setBytes(long, byte[]) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data from a given byte array into this ArrowBuf starting at a given index.
setBytes(long, byte[], int, long) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data from a given byte array starting at the given source index into this ArrowBuf at a given index.
setBytes(long, ByteBuffer) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data into this ArrowBuf at a given index onwards from a source ByteBuffer.
setBytes(long, ByteBuffer, int, int) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data into this ArrowBuf at a given index onwards from a source ByteBuffer starting at a given srcIndex for a certain length.
setBytes(long, ArrowBuf, long, long) - Method in class org.apache.arrow.memory.ArrowBuf
Copy data from src ArrowBuf starting at index srcIndex into this ArrowBuf at given index.
setBytes(long, ArrowBuf) - Method in class org.apache.arrow.memory.ArrowBuf
Copy readableBytes() number of bytes from src ArrowBuf starting from its readerIndex into this ArrowBuf starting at the given index.
setBytes(long, InputStream, int) - Method in class org.apache.arrow.memory.ArrowBuf
Copy a certain length of bytes from given InputStream into this ArrowBuf at the provided index.
setBytes(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
setBytes(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
setCalendar(Calendar) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Sets the Calendar to use when constructing timestamp fields in the Arrow schema, and reading time-based fields from the JDBC ResultSet.
setCapacity(int, boolean) - Method in class org.apache.arrow.vector.util.ReusableByteArray
Sets the capacity of this object to at least len bytes.
setCatalog(String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies the Catalog to search for the tables.
setCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the catalog to search for the foreign key table.
setCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the catalog to search for the primary key table.
setCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the catalog to search for the table.
setCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies the Catalog to search for the tables.
setCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies the Catalog to search for the tables.
setCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the catalog to search for the foreign key table.
setCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the catalog to search for the primary key table.
setCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the catalog to search for the table.
setCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies the Catalog to search for the tables.
setChar(int, int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setChar(long, int) - Method in class org.apache.arrow.memory.ArrowBuf
Set char value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setClientInfo(String, String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setClientInfo(Properties) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setCmd(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
Opaque value used to express a command.
setColumnMetadataByColumnIndex(Map<Integer, Map<String, String>>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Set metadata from columnIndex->meta map on per field basis.
setConflictPolicy(AbstractStructVector.ConflictPolicy) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Set conflict policy and return last conflict policy state.
setConflictPolicy(AbstractStructVector.ConflictPolicy) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
setDataBody(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The actual batch of Arrow data.
setDataHeader(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
Header for message data as described in Message.fbs::Message.
setDatasetSchema(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
If a result set generating query was provided, dataset_schema contains the schema of the result set.
setDataType(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
Specifies the data type to search for the info.
setDbSchema(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the schema to search for the foreign key table.
setDbSchema(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the schema to search for the primary key table.
setDbSchema(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the schema to search for the table.
setDbSchemaBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the schema to search for the foreign key table.
setDbSchemaBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the schema to search for the primary key table.
setDbSchemaBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the schema to search for the table.
setDbSchemaFilterPattern(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies a filter pattern for schemas to search for.
setDbSchemaFilterPattern(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for schemas to search for.
setDbSchemaFilterPatternBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
Specifies a filter pattern for schemas to search for.
setDbSchemaFilterPatternBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for schemas to search for.
setDefinition(PerfOuterClass.Perf) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
setDefinition(PerfOuterClass.Perf.Builder) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
definition of entire flight.
setDescription(String) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string description = 2;
setDescriptionBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string description = 2;
setDouble(int, double) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setDouble(long, double) - Method in class org.apache.arrow.memory.ArrowBuf
Set double value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setEnd(long) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
exclusive end
setEndpoint(int, Flight.FlightEndpoint) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
setEndpoint(int, Flight.FlightEndpoint.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
A list of endpoints associated with the flight.
setEndpoint(Flight.FlightEndpoint) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
setEndpoint(Flight.FlightEndpoint.Builder) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
.arrow.flight.protocol.FlightEndpoint endpoint = 1;
setExpirationTime(Instant) - Method in class org.apache.arrow.flight.FlightEndpoint.Builder
Set expiration time for the endpoint.
setExpirationTime(Timestamp) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
setExpirationTime(Timestamp.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Expiration time of this stream.
setExpirationTime(Timestamp) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
setExpirationTime(Timestamp.Builder) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Expiration time for this request.
setExplicitTypesByColumnIndex(Map<Integer, JdbcFieldInfo>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Sets the mapping of column-index-to-JdbcFieldInfo used for column types.
setExplicitTypesByColumnName(Map<String, JdbcFieldInfo>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Sets the mapping of column-name-to-JdbcFieldInfo used for column types.
setExpression(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
bytes expression = 1;
setFkCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the foreign table is.
setFkCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the foreign table is.
setFkDbSchema(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The schema name where the foreign table is.
setFkDbSchemaBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The schema name where the foreign table is.
setFkTable(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The foreign table name.
setFkTableBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The foreign table name.
setFlightDescriptor(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
setFlightDescriptor(Flight.FlightDescriptor.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
The descriptor of the data.
setFlightDescriptor(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
setFlightDescriptor(Flight.FlightDescriptor.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The descriptor associated with this info.
setFlightDescriptor(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
setFlightDescriptor(Flight.FlightDescriptor.Builder) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The descriptor the client should use on the next try.
setFloat(int, float) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setFloat(long, float) - Method in class org.apache.arrow.memory.ArrowBuf
Set float value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setHoldability(int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setIncludeMetadata(boolean) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Sets whether to include JDBC ResultSet field metadata in the Arrow Schema field metadata.
setIncludeSchema(boolean) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies if the Arrow schema should be returned for found tables.
setIndexDefined(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Mark the particular position in the vector as non-null.
setIndexDefined(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Mark the particular position in the vector as non-null.
setIndexDefined(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Mark the particular position in the vector as non-null.
setIndexDefined(int) - Method in class org.apache.arrow.vector.complex.StructVector
Marks the value at index as being set.
setIndexDefined(int) - Method in interface org.apache.arrow.vector.VectorDefinitionSetter
 
setInfo(Flight.FlightInfo) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
setInfo(Flight.FlightInfo.Builder) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
.arrow.flight.protocol.FlightInfo info = 1;
setInfo(Flight.FlightInfo) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
setInfo(Flight.FlightInfo.Builder) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
The currently available results.
setInfo(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
The result of the GetFlightInfo RPC that initiated the query.
setInfo(int, int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
Values are modelled after ODBC's SQLGetInfo() function.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Sets the desired value capacity for the vector.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Sets the desired value capacity for the vector.
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Sets the desired value capacity for the vector.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Sets the desired value capacity for the vector.
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Sets the desired value capacity for the vector.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.BitVector
Sets the desired value capacity for the vector.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Specialized version of setInitialCapacity() for ListVector.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.LargeListVector
Specialized version of setInitialCapacity() for ListVector.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.ListVector
 
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.ListVector
Specialized version of setInitialCapacity() for ListVector.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.StructVector
 
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.StructVector
 
setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setInitialCapacity(int, double) - Method in interface org.apache.arrow.vector.DensityAwareVector
Set value with density.
setInitialCapacity(int) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
setInitialCapacity(int) - Method in class org.apache.arrow.vector.NullVector
 
setInitialCapacity(int) - Method in interface org.apache.arrow.vector.ValueVector
Set the initial record capacity.
setInitialTotalCapacity(int, int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Specialized version of setInitialTotalCapacity() for ListVector.
setInitialTotalCapacity(int, int) - Method in class org.apache.arrow.vector.complex.LargeListVector
Specialized version of setInitialTotalCapacity() for ListVector.
setInitialTotalCapacity(int, int) - Method in class org.apache.arrow.vector.complex.ListVector
Specialized version of setInitialTotalCapacity() for ListVector.
setInt(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setInt(int, int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setInt(long, int) - Method in class org.apache.arrow.memory.ArrowBuf
Set int value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setJdbcConsumerGetter(JdbcToArrowConfig.JdbcConsumerFactory) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Set the function used to get a JDBC consumer for a given type.
setJdbcToArrowTypeConverter(Function<JdbcFieldInfo, ArrowType>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Set the function used to convert JDBC types to Arrow types.
setKeyValueNames(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionMapReader
Set the key, value field names to read.
setLastSet(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Set the index of last non-null element in the vector.
setLastSet(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Set the index of last non-null element in the vector.
setLastSet(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
 
setLastSet(int) - Method in class org.apache.arrow.vector.complex.ListVector
 
setLeftStart(int) - Method in class org.apache.arrow.vector.compare.Range
 
setLength(int) - Method in class org.apache.arrow.vector.compare.Range
 
setLimit(long) - Method in interface org.apache.arrow.memory.BufferAllocator
Set the maximum amount of memory this allocator is allowed to allocate.
setLocation(int, Flight.Location) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
setLocation(int, Flight.Location.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
A list of URIs where this ticket can be redeemed via DoGet().
setLocation(Location) - Method in class org.apache.arrow.flight.integration.tests.IntegrationProducer
Update the location after server start.
setLoginTimeout(int) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
setLogWriter(PrintWriter) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
setLong(int, long) - Method in class io.netty.buffer.NettyArrowBuf
 
setLong(int, long) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setLong(long, long) - Method in class org.apache.arrow.memory.ArrowBuf
Set long value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setMedium(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setName(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
Name for the savepoint.
setNameBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
Name for the savepoint.
setNetworkTimeout(Executor, int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setNotNull(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Sets the value at index to not-null.
setNotNull(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
Sets the list at index to be not-null.
setNotNull(int) - Method in class org.apache.arrow.vector.complex.ListVector
Sets the list at index to be not-null.
setNull(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Set the element at the given index to null.
setNull(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Set the element at the given index to null.
setNull(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Set the element at the given index to null.
setNull(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
Set the element at the given index to null.
setNull(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Sets the value at index to null.
setNull(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
Sets list at index to be null.
setNull(int) - Method in class org.apache.arrow.vector.complex.ListVector
Sets list at index to be null.
setNull(int) - Method in class org.apache.arrow.vector.complex.StructVector
Marks the value at index as null/not set.
setNull(int) - Method in class org.apache.arrow.vector.complex.UnionVector
Set the element at the given index to null.
setNull(int) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
setNull(int) - Method in interface org.apache.arrow.vector.FieldVector
Set the element at the given index to null.
setNull(int) - Method in class org.apache.arrow.vector.NullVector
Set the element at the given index to null.
setOnCancelHandler(Runnable) - Method in interface org.apache.arrow.flight.FlightProducer.ServerStreamListener
Set a callback for when the client cancels a call, i.e.
setOnColumnMetaDataBuilder(Common.ColumnMetaData.Builder, Map<String, String>) - Static method in class org.apache.arrow.driver.jdbc.utils.ConvertUtils
Set on Column MetaData Builder.
setOne(int, int) - Method in class org.apache.arrow.memory.ArrowBuf
Deprecated.
setOne(long, long) - Method in class org.apache.arrow.memory.ArrowBuf
Sets all bits to one in the specified range.
setOnReadyHandler(Runnable) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Set a callback for when the listener is ready for new calls to putNext(), i.e.
setOption(IpcOption) - Method in class org.apache.arrow.flight.FlightInfo.Builder
Set IPC write options.
setOrdered(boolean) - Method in class org.apache.arrow.flight.FlightInfo.Builder
Set whether the flight endpoints are ordered.
setOrdered(boolean) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
FlightEndpoints are in the same order as the data.
setParameters(VectorSchemaRoot) - Method in interface org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.PreparedStatement
 
setParameters(VectorSchemaRoot) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
Set the FlightSqlClient.PreparedStatement.parameterBindingRoot containing the parameter binding from a FlightSqlClient.PreparedStatement operation.
setParameterSchema(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
If the query provided contained parameters, parameter_schema contains the schema of the expected parameters.
setPassword(String) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string password = 3;
setPasswordBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string password = 3;
setPath(int, String) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
List of strings identifying a particular dataset.
setPayload(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
Arbitrary auth/handshake info.
setPayload(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
Arbitrary auth/handshake info.
setPkCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the parent table is.
setPkCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The catalog name where the parent table is.
setPkDbSchema(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The Schema name where the parent table is.
setPkDbSchemaBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The Schema name where the parent table is.
setPkTable(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The parent table name.
setPkTableBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
The parent table name.
setPlan(FlightSql.SubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
setPlan(FlightSql.SubstraitPlan.Builder) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
The serialized substrait.Plan to create a prepared statement for.
setPlan(FlightSql.SubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
setPlan(FlightSql.SubstraitPlan.Builder) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
A serialized substrait.Plan
setPlan(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The serialized substrait.Plan to create a prepared statement for.
setPosition(int) - Method in class org.apache.arrow.consumers.BaseAvroConsumer
 
setPosition(int) - Method in interface org.apache.arrow.consumers.Consumer
Set the position to write value into vector.
setPosition(int) - Method in class org.apache.arrow.consumers.SkipConsumer
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
setPosition(int) - Method in interface org.apache.arrow.vector.complex.Positionable
 
setPosition(int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
setPosition(long) - Method in class org.apache.arrow.vector.ipc.SeekableReadChannel
 
setPosition(int) - Method in class org.apache.arrow.vector.table.Row
Moves this Row to the given 0-based row index.
setPreparedStatementHandle(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
Opaque handle for the prepared statement on the server.
setPreparedStatementHandle(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
Opaque handle for the prepared statement on the server.
setPreparedStatementHandle(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
Opaque handle for the prepared statement on the server.
setPreparedStatementHandle(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
Opaque handle for the prepared statement on the server.
setProgress(double) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
Query progress.
setProtocolVersion(long) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
A defined protocol version
setProtocolVersion(long) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
A defined protocol version
setProvider(DictionaryProvider.MapDictionaryProvider) - Method in class org.apache.arrow.AvroToArrowConfigBuilder
 
setQuery(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
The valid SQL string to create a prepared statement for.
setQuery(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
The SQL syntax.
setQuery(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
The SQL syntax.
setQueryBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
The valid SQL string to create a prepared statement for.
setQueryBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
The SQL syntax.
setQueryBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
The SQL syntax.
setRangeToOne(int, int) - Method in class org.apache.arrow.vector.BitVector
Set count bits to 1 in data starting at firstBitIndex.
setReadOnly(boolean) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setRecordCount(long) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
The number of records updated.
setRecords(long) - Method in class org.apache.arrow.flight.FlightInfo.Builder
Set the number of records for the flight.
setRecordsPerBatch(int) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int32 records_per_batch = 4;
setRecordsPerStream(long) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int64 records_per_stream = 3;
setResult(FlightSql.ActionCancelQueryResult.CancelResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
setResultValue(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
.arrow.flight.protocol.sql.ActionCancelQueryResult.CancelResult result = 1;
setReuseVectorSchemaRoot(boolean) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Set whether to use the same VectorSchemaRoot instance on each iteration, or to allocate a new one.
setRightStart(int) - Method in class org.apache.arrow.vector.compare.Range
 
setRowCount(int) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Set the row count of all the vectors in this container.
setSafe(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
setSafe(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
 
setSafe(int, byte[]) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Same as BaseLargeVariableWidthVector.set(int, byte[]) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Same as BaseLargeVariableWidthVector.set(int, byte[], int, int) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Same as BaseLargeVariableWidthVector.set(int, ByteBuffer, int, int) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, int, long, long, ArrowBuf) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Same as BaseLargeVariableWidthVector.set(int, int, long, long, ArrowBuf) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, long, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Same as BaseLargeVariableWidthVector.set(int, int, long, long, ArrowBuf) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, byte[]) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Same as BaseVariableWidthVector.set(int, byte[]) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Same as BaseVariableWidthVector.set(int, byte[], int, int) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Same as BaseVariableWidthVector.set(int, ByteBuffer, int, int) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, int, int, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Same as BaseVariableWidthVector.set(int, int, int, int, ArrowBuf) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Same as BaseVariableWidthVector.set(int, int, int, int, ArrowBuf) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, long) - Method in class org.apache.arrow.vector.BigIntVector
Same as BigIntVector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.BigIntVector
Same as BigIntVector.set(int, NullableBigIntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, BigIntHolder) - Method in class org.apache.arrow.vector.BigIntVector
Same as BigIntVector.set(int, BigIntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long) - Method in class org.apache.arrow.vector.BigIntVector
Same as BigIntVector.set(int, int, long) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.BitVector
Same as BitVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableBitHolder) - Method in class org.apache.arrow.vector.BitVector
Same as BitVector.set(int, NullableBitHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, BitHolder) - Method in class org.apache.arrow.vector.BitVector
Same as BitVector.set(int, BitHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.BitVector
Same as BitVector.set(int, int, int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, NullableBitHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setSafe(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, UnionHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableDurationHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampSecTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampMilliTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampMicroTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeStampNanoTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableDecimal256Holder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableDecimalHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableFixedSizeBinaryHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, NullableBitHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setSafe(int, int) - Method in class org.apache.arrow.vector.DateDayVector
Same as DateDayVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.DateDayVector
Same as DateDayVector.set(int, NullableDateDayHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, DateDayHolder) - Method in class org.apache.arrow.vector.DateDayVector
Same as DateDayVector.set(int, DateDayHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.DateDayVector
Same as DateDayVector.set(int, int, int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, long) - Method in class org.apache.arrow.vector.DateMilliVector
Same as DateMilliVector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.DateMilliVector
Same as DateMilliVector.set(int, NullableDateMilliHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, DateMilliHolder) - Method in class org.apache.arrow.vector.DateMilliVector
Same as DateMilliVector.set(int, DateMilliHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long) - Method in class org.apache.arrow.vector.DateMilliVector
Same as DateMilliVector.set(int, int, long) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, long, ArrowBuf, int) - Method in class org.apache.arrow.vector.Decimal256Vector
Sets the element at given index using the buffer whose size maybe <= 32 bytes.
setSafe(int, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as Decimal256Vector.set(int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, long, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as #set(int, int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, BigDecimal) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as Decimal256Vector.set(int, BigDecimal) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, long) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as Decimal256Vector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as #set(int, NullableDecimalHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, Decimal256Holder) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as Decimal256Vector.set(int, Decimal256Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
Same as #setSafe(int, int, int, ArrowBuf) except that it handles the case when the position of new value is beyond the current value capacity of the vector.
setSafe(int, long, ArrowBuf, int) - Method in class org.apache.arrow.vector.DecimalVector
Sets the element at given index using the buffer whose size maybe <= 16 bytes.
setSafe(int, ArrowBuf) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.set(int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, long, ArrowBuf) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.set(int, long, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, BigDecimal) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.set(int, BigDecimal) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, long) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.set(int, NullableDecimalHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, DecimalHolder) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.set(int, DecimalHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long, ArrowBuf) - Method in class org.apache.arrow.vector.DecimalVector
Same as DecimalVector.set(int, int, long, ArrowBuf) except that it handles the case when the position of new value is beyond the current value capacity of the vector.
setSafe(int, ArrowBuf) - Method in class org.apache.arrow.vector.DurationVector
Same as DurationVector.set(int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, long) - Method in class org.apache.arrow.vector.DurationVector
Same as DurationVector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableDurationHolder) - Method in class org.apache.arrow.vector.DurationVector
Same as DurationVector.set(int, NullableDurationHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, DurationHolder) - Method in class org.apache.arrow.vector.DurationVector
Same as DurationVector.set(int, DurationHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long) - Method in class org.apache.arrow.vector.DurationVector
Same as DurationVector.set(int, int, long) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, byte[]) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Same as FixedSizeBinaryVector.set(int, byte[]) but reallocates if index is larger than capacity.
setSafe(int, int, byte[]) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
 
setSafe(int, ArrowBuf) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Same as FixedSizeBinaryVector.set(int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Same as FixedSizeBinaryVector.set(int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Same as FixedSizeBinaryVector.set(int, FixedSizeBinaryHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
Same as FixedSizeBinaryVector.set(int, NullableFixedSizeBinaryHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, float) - Method in class org.apache.arrow.vector.Float4Vector
Same as Float4Vector.set(int, float) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.Float4Vector
Same as Float4Vector.set(int, NullableFloat4Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, Float4Holder) - Method in class org.apache.arrow.vector.Float4Vector
Same as Float4Vector.set(int, Float4Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, float) - Method in class org.apache.arrow.vector.Float4Vector
Same as Float4Vector.set(int, int, float) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, double) - Method in class org.apache.arrow.vector.Float8Vector
Same as Float8Vector.set(int, double) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.Float8Vector
Same as Float8Vector.set(int, NullableFloat8Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, Float8Holder) - Method in class org.apache.arrow.vector.Float8Vector
Same as Float8Vector.set(int, Float8Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, double) - Method in class org.apache.arrow.vector.Float8Vector
Same as Float8Vector.set(int, int, double) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, ArrowBuf) - Method in class org.apache.arrow.vector.IntervalDayVector
Same as IntervalDayVector.set(int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.IntervalDayVector
Same as IntervalDayVector.set(int, int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.IntervalDayVector
Same as IntervalDayVector.set(int, NullableIntervalDayHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, IntervalDayHolder) - Method in class org.apache.arrow.vector.IntervalDayVector
Same as IntervalDayVector.set(int, IntervalDayHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int, int) - Method in class org.apache.arrow.vector.IntervalDayVector
Same as IntervalDayVector.set(int, int, int, int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, ArrowBuf) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Same as IntervalMonthDayNanoVector.set(int, ArrowBuf) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int, long) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Same as IntervalMonthDayNanoVector.set(int, int, int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Same as IntervalMonthDayNanoVector.set(int, NullableIntervalMonthDayNanoHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Same as IntervalMonthDayNanoVector.set(int, IntervalMonthDayNanoHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int, int, long) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
Same as IntervalMonthDayNanoVector.set(int, int, int, int, long) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.IntervalYearVector
Same as IntervalYearVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.IntervalYearVector
Same as IntervalYearVector.set(int, NullableIntervalYearHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, IntervalYearHolder) - Method in class org.apache.arrow.vector.IntervalYearVector
Same as IntervalYearVector.set(int, IntervalYearHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.IntervalYearVector
Same as IntervalYearVector.set(int, int, int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.IntVector
Same as IntVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableIntHolder) - Method in class org.apache.arrow.vector.IntVector
Same as IntVector.set(int, NullableIntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, IntHolder) - Method in class org.apache.arrow.vector.IntVector
Same as IntVector.set(int, IntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.IntVector
Same as IntVector.set(int, int, int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Same as LargeVarBinaryVector.set(int, LargeVarBinaryHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
Same as LargeVarBinaryVector.set(int, NullableLargeVarBinaryHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, LargeVarCharHolder) - Method in class org.apache.arrow.vector.LargeVarCharVector
Same as LargeVarCharVector.set(int, LargeVarCharHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.LargeVarCharVector
Same as LargeVarCharVector.set(int, NullableLargeVarCharHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, Text) - Method in class org.apache.arrow.vector.LargeVarCharVector
Same as LargeVarCharVector.set(int, NullableLargeVarCharHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.SmallIntVector
Same as SmallIntVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, short) - Method in class org.apache.arrow.vector.SmallIntVector
Same as SmallIntVector.set(int, short) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.SmallIntVector
Same as SmallIntVector.set(int, NullableSmallIntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, SmallIntHolder) - Method in class org.apache.arrow.vector.SmallIntVector
Same as SmallIntVector.set(int, SmallIntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, short) - Method in class org.apache.arrow.vector.SmallIntVector
Same as SmallIntVector.set(int, int, short) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, long) - Method in class org.apache.arrow.vector.TimeMicroVector
Same as TimeMicroVector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.TimeMicroVector
Same as TimeMicroVector.set(int, NullableTimeMicroHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeMicroHolder) - Method in class org.apache.arrow.vector.TimeMicroVector
Same as TimeMicroVector.set(int, TimeMicroHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long) - Method in class org.apache.arrow.vector.TimeMicroVector
Same as TimeMicroVector.set(int, int, long) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.TimeMilliVector
Same as TimeMilliVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.TimeMilliVector
Same as TimeMilliVector.set(int, NullableTimeMilliHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeMilliHolder) - Method in class org.apache.arrow.vector.TimeMilliVector
Same as TimeMilliVector.set(int, TimeMilliHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.TimeMilliVector
Same as TimeMilliVector.set(int, int, int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, long) - Method in class org.apache.arrow.vector.TimeNanoVector
Same as TimeNanoVector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.TimeNanoVector
Same as TimeNanoVector.set(int, NullableTimeNanoHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeNanoHolder) - Method in class org.apache.arrow.vector.TimeNanoVector
Same as TimeNanoVector.set(int, TimeNanoHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long) - Method in class org.apache.arrow.vector.TimeNanoVector
Same as TimeNanoVector.set(int, int, long) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.TimeSecVector
Same as TimeSecVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.TimeSecVector
Same as TimeSecVector.set(int, NullableTimeSecHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeSecHolder) - Method in class org.apache.arrow.vector.TimeSecVector
Same as TimeSecVector.set(int, TimeSecHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.TimeSecVector
Same as TimeSecVector.set(int, int, int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Same as TimeStampMicroTZVector.set(int, NullableTimeStampMicroTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
Same as TimeStampMicroTZVector.set(int, TimeStampMicroTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Same as TimeStampMicroVector.set(int, NullableTimeStampMicroHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampMicroHolder) - Method in class org.apache.arrow.vector.TimeStampMicroVector
Same as TimeStampMicroVector.set(int, TimeStampMicroHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Same as TimeStampMilliTZVector.set(int, NullableTimeStampMilliTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
Same as TimeStampMilliTZVector.set(int, TimeStampMilliTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Same as TimeStampMilliVector.set(int, NullableTimeStampMilliHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampMilliHolder) - Method in class org.apache.arrow.vector.TimeStampMilliVector
Same as TimeStampMilliVector.set(int, TimeStampMilliHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Same as TimeStampNanoTZVector.set(int, NullableTimeStampNanoTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
Same as TimeStampNanoTZVector.set(int, TimeStampNanoTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Same as TimeStampNanoVector.set(int, NullableTimeStampNanoHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampNanoHolder) - Method in class org.apache.arrow.vector.TimeStampNanoVector
Same as TimeStampNanoVector.set(int, TimeStampNanoHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Same as TimeStampSecTZVector.set(int, NullableTimeStampSecTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
Same as TimeStampSecTZVector.set(int, TimeStampSecTZHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.TimeStampSecVector
Same as TimeStampSecVector.set(int, NullableTimeStampSecHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TimeStampSecHolder) - Method in class org.apache.arrow.vector.TimeStampSecVector
Same as TimeStampSecVector.set(int, TimeStampSecHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, long) - Method in class org.apache.arrow.vector.TimeStampVector
Same as TimeStampVector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long) - Method in class org.apache.arrow.vector.TimeStampVector
Same as TimeStampVector.set(int, int, long) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.TinyIntVector
Same as TinyIntVector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, byte) - Method in class org.apache.arrow.vector.TinyIntVector
Same as TinyIntVector.set(int, byte) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.TinyIntVector
Same as TinyIntVector.set(int, NullableTinyIntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, TinyIntHolder) - Method in class org.apache.arrow.vector.TinyIntVector
Same as TinyIntVector.set(int, TinyIntHolder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, byte) - Method in class org.apache.arrow.vector.TinyIntVector
Same as TinyIntVector.set(int, int, byte) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafe(int, int) - Method in class org.apache.arrow.vector.UInt1Vector
Same as UInt1Vector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, byte) - Method in class org.apache.arrow.vector.UInt1Vector
Same as UInt1Vector.set(int, byte) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.UInt1Vector
Same as UInt1Vector.set(int, NullableUInt1Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, UInt1Holder) - Method in class org.apache.arrow.vector.UInt1Vector
Same as UInt1Vector.set(int, UInt1Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, byte) - Method in class org.apache.arrow.vector.UInt1Vector
Same as UInt1Vector.set(int, int, byte) but will reallocate the buffer if index is larger than current capacity.
setSafe(int, int) - Method in class org.apache.arrow.vector.UInt2Vector
Same as UInt2Vector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, char) - Method in class org.apache.arrow.vector.UInt2Vector
Same as UInt2Vector.set(int, char) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.UInt2Vector
Same as UInt2Vector.set(int, NullableUInt2Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, UInt2Holder) - Method in class org.apache.arrow.vector.UInt2Vector
Same as UInt2Vector.set(int, UInt2Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, char) - Method in class org.apache.arrow.vector.UInt2Vector
Same as UInt2Vector.set(int, int, char) but will reallocate the buffer if index is larger than current capacity.
setSafe(int, int) - Method in class org.apache.arrow.vector.UInt4Vector
Same as UInt4Vector.set(int, int) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.UInt4Vector
Same as UInt4Vector.set(int, NullableUInt4Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, UInt4Holder) - Method in class org.apache.arrow.vector.UInt4Vector
Same as UInt4Vector.set(int, UInt4Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, int) - Method in class org.apache.arrow.vector.UInt4Vector
Same as UInt4Vector.set(int, int, int) but will reallocate if the buffer if index is larger than the current capacity.
setSafe(int, long) - Method in class org.apache.arrow.vector.UInt8Vector
Same as UInt8Vector.set(int, long) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.UInt8Vector
Same as UInt8Vector.set(int, NullableUInt8Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, UInt8Holder) - Method in class org.apache.arrow.vector.UInt8Vector
Same as UInt8Vector.set(int, UInt8Holder) except that it handles the case when index is greater than or equal to existing value capacity BaseFixedWidthVector.getValueCapacity().
setSafe(int, int, long) - Method in class org.apache.arrow.vector.UInt8Vector
Same as UInt8Vector.set(int, int, long) but will reallocate if index is greater than current capacity.
setSafe(int, VarBinaryHolder) - Method in class org.apache.arrow.vector.VarBinaryVector
Same as VarBinaryVector.set(int, VarBinaryHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.VarBinaryVector
Same as VarBinaryVector.set(int, NullableVarBinaryHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, VarCharHolder) - Method in class org.apache.arrow.vector.VarCharVector
Same as VarCharVector.set(int, VarCharHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.VarCharVector
Same as VarCharVector.set(int, NullableVarCharHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafe(int, Text) - Method in class org.apache.arrow.vector.VarCharVector
Same as VarCharVector.set(int, NullableVarCharHolder) except that it handles the case where index and length of new element are beyond the existing capacity of the vector.
setSafeToOne(int) - Method in class org.apache.arrow.vector.BitVector
Same as BitVector.setToOne(int) except that it handles the case when index is greater than or equal to current value capacity of the vector.
setSafeWithPossibleTruncate(int, double) - Method in class org.apache.arrow.vector.Float4Vector
 
setSafeWithPossibleTruncate(int, double) - Method in class org.apache.arrow.vector.Float8Vector
 
setSafeWithPossibleTruncate(int, double) - Method in interface org.apache.arrow.vector.FloatingPointVector
Sets the value at the given index, note this value may be truncated internally.
setSavepoint() - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setSavepoint(String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setSavepointId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
Opaque handle for the savepoint on the server.
setSavepointId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
Opaque handle for the savepoint on the server.
setSchema(String) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setSchema(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
setSchema(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
The schema of the dataset in its IPC form: 4 bytes - an optional IPC_CONTINUATION_TOKEN prefix 4 bytes - the byte length of the payload a flatbuffer Message whose header is the Schema
setSchema(ByteString) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
bytes schema = 1;
setSchemaMetadata(Map<String, String>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Set metadata for schema.
setShort(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
setShort(int, int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
setShort(long, int) - Method in class org.apache.arrow.memory.ArrowBuf
Set short value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setShort(long, short) - Method in class org.apache.arrow.memory.ArrowBuf
Set short value at a particular index in the underlying memory chunk this ArrowBuf has access to.
setSkipFieldNames(Set<String>) - Method in class org.apache.arrow.AvroToArrowConfigBuilder
 
setStart(long) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
inclusive start
setStatementHandle(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
Unique identifier for the instance of the statement to execute.
setStatus(Flight.CancelStatus) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
.arrow.flight.protocol.CancelStatus status = 1;
setStatusValue(int) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
.arrow.flight.protocol.CancelStatus status = 1;
setStreamCount(int) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
int32 stream_count = 2;
setTable(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the foreign key table to get the foreign keys for.
setTable(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the primary key table to get the foreign keys for.
setTable(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the table to get the primary keys for.
setTableBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
Specifies the foreign key table to get the foreign keys for.
setTableBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
Specifies the primary key table to get the foreign keys for.
setTableBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
Specifies the table to get the primary keys for.
setTableNameFilterPattern(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for tables to search for.
setTableNameFilterPatternBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter pattern for tables to search for.
setTableTypes(int, String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
Specifies a filter of table types which must match.
setTargetBatchSize(int) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
Set the target number of rows to convert at once.
setTargetBatchSize(int) - Method in class org.apache.arrow.AvroToArrowConfigBuilder
 
setTicket(Flight.Ticket) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
setTicket(Flight.Ticket.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
Token used to retrieve this stream.
setTicket(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
bytes ticket = 1;
setToOne(int) - Method in class org.apache.arrow.vector.BitVector
Set the element at the given index to one.
setTotalBytes(long) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
int64 total_bytes = 5;
setTotalRecords(long) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
Set these to -1 if unknown.
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
The transaction to which a savepoint belongs.
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
Opaque handle for the transaction on the server.
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
Create/execute the prepared statement as part of this transaction (if unset, executions of the prepared statement will be auto-committed).
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
Opaque handle for the transaction on the server.
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
setTransactionId(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
Include the query as part of this transaction (if unset, the query is auto-committed).
setTransactionIsolation(int) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setType(String) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
string type = 1;
setType(String) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string type = 1;
setType(Flight.FlightDescriptor.DescriptorType) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
setType(int, Types.MinorType) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setTypeBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
string type = 1;
setTypeBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
string type = 1;
setTypeId(int, byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setTypeMap(Map<String, Class<?>>) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
setTypeValue(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
.arrow.flight.protocol.FlightDescriptor.DescriptorType type = 1;
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
 
setUnsafeWithPossibleTruncate(int, long) - Method in interface org.apache.arrow.vector.BaseIntVector
Sets the value at index, note this value may need to be truncated.
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.BigIntVector
 
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.IntVector
 
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.SmallIntVector
 
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.TinyIntVector
 
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt1Vector
 
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt2Vector
 
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt4Vector
 
setUnsafeWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt8Vector
 
setUri(String) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
string uri = 1;
setUriBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
string uri = 1;
setUsername(String) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string username = 2;
setUsernameBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
string username = 2;
setUseZeroCopy(boolean) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Toggle whether to use the zero-copy write optimization.
setValidityBit(ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Set the bit at a given index to provided value (1 or 0).
setValidityBit(ArrowBuf, BufferAllocator, int, int, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Set the bit at a given index to provided value (1 or 0).
setValue(int, long) - Method in class org.apache.arrow.vector.TimeStampVector
 
setValueCount(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Set value count for the vector.
setValueCount(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Sets the value count for the vector.
setValueCount(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Sets the value count for the vector.
setValueCount(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Preallocates the number of repeated values.
setValueCount(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
Sets the value count for the vector.
setValueCount(int) - Method in class org.apache.arrow.vector.complex.ListVector
Sets the value count for the vector.
setValueCount(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.StructVector
 
setValueCount(int) - Method in class org.apache.arrow.vector.complex.UnionVector
 
setValueCount(int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
 
setValueCount(int) - Method in class org.apache.arrow.vector.ExtensionTypeVector
 
setValueCount(int) - Method in class org.apache.arrow.vector.NullVector
 
setValueCount(int) - Method in interface org.apache.arrow.vector.ValueVector
Set number of values in the vector.
setValueCount(int) - Method in class org.apache.arrow.vector.ZeroVector
 
setValueLengthSafe(int, int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Sets the value length for an element.
setValueLengthSafe(int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Sets the value length for an element.
setVersion(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The Substrait release, e.g.
setVersionBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
The Substrait release, e.g.
setWasNull(boolean) - Method in interface org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessorFactory.WasNullConsumer
 
setWithPossibleTruncate(int, long) - Method in interface org.apache.arrow.vector.BaseIntVector
Sets the value at index, note this value may need to be truncated.
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.BigIntVector
 
setWithPossibleTruncate(int, double) - Method in class org.apache.arrow.vector.Float4Vector
 
setWithPossibleTruncate(int, double) - Method in class org.apache.arrow.vector.Float8Vector
 
setWithPossibleTruncate(int, double) - Method in interface org.apache.arrow.vector.FloatingPointVector
Sets the value at the given index, note this value may be truncated internally.
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.IntVector
 
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.SmallIntVector
 
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.TinyIntVector
 
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt1Vector
 
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt2Vector
 
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt4Vector
 
setWithPossibleTruncate(int, long) - Method in class org.apache.arrow.vector.UInt8Vector
 
setZero(long, long) - Method in class org.apache.arrow.memory.ArrowBuf
Zero-out the bytes in this ArrowBuf starting at the given index for the given length.
shape(int) - Method in class org.apache.arrow.flatbuf.SparseTensor
The dimensions of the tensor, optionally named.
shape(TensorDim, int) - Method in class org.apache.arrow.flatbuf.SparseTensor
 
shape(int) - Method in class org.apache.arrow.flatbuf.Tensor
The dimensions of the tensor, optionally named
shape(TensorDim, int) - Method in class org.apache.arrow.flatbuf.Tensor
 
shapeLength() - Method in class org.apache.arrow.flatbuf.SparseTensor
 
shapeLength() - Method in class org.apache.arrow.flatbuf.Tensor
 
shapeVector() - Method in class org.apache.arrow.flatbuf.SparseTensor
 
shapeVector(TensorDim.Vector) - Method in class org.apache.arrow.flatbuf.SparseTensor
 
shapeVector() - Method in class org.apache.arrow.flatbuf.Tensor
 
shapeVector(TensorDim.Vector) - Method in class org.apache.arrow.flatbuf.Tensor
 
ShortComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.ShortComparator
 
shouldContinueWaiting(FlightProducer.ServerStreamListener, long) - Method in class org.apache.arrow.flight.BackpressureStrategy.CallbackBackpressureStrategy
Callback function to run to check if the listener should continue to be waited on if it leaves the waiting state without being cancelled, ready, or timed out.
shouldIncludeMetadata() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
Whether to include JDBC ResultSet field metadata in the Arrow Schema field metadata.
shutdown() - Method in class org.apache.arrow.flight.FlightServer
Request that the server shut down.
shutdown() - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
shutdownNow() - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
SimpleHasher - Class in org.apache.arrow.memory.util.hash
A simple hasher that calculates the hash code of integers as is, and does not perform any finalization.
SimpleHasher() - Constructor for class org.apache.arrow.memory.util.hash.SimpleHasher
 
SINGLE - Static variable in class org.apache.arrow.flatbuf.Precision
 
SingleCaseSensitiveStructWriter - Class in org.apache.arrow.vector.complex.impl
 
SingleCaseSensitiveStructWriter(NonNullableStructVector) - Constructor for class org.apache.arrow.vector.complex.impl.SingleCaseSensitiveStructWriter
 
SingleListReaderImpl - Class in org.apache.arrow.vector.complex.impl
An implementation of AbstractFieldReader for lists vectors.
SingleListReaderImpl(String, AbstractContainerVector) - Constructor for class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
Constructs a new instance.
SingleStructReaderImpl - Class in org.apache.arrow.vector.complex.impl
SingleStructReaderImpl(NonNullableStructVector) - Constructor for class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
 
SingleStructWriter - Class in org.apache.arrow.vector.complex.impl
 
SingleStructWriter(NonNullableStructVector) - Constructor for class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
size() - Method in class org.apache.arrow.flatbuf.TensorDim
Length of dimension
size() - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
Returns the number of mappings in this Map.
size() - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
size() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
Get the number of child vectors.
size() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Get value indicating if inner vector is set.
size() - Method in class org.apache.arrow.vector.complex.DenseUnionVector
 
size() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Get value indicating if inner vector is set.
size() - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
 
size() - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
size() - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
 
size() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
size() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
 
size() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
 
size() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
size() - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
size() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedListReader
 
size() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedMapReader
 
size() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedStructReader
 
size() - Method in class org.apache.arrow.vector.complex.UnionVector
 
size() - Method in class org.apache.arrow.vector.dictionary.DictionaryHashTable
Returns the number of mappings in this Map.
size() - Method in class org.apache.arrow.vector.ipc.SeekableReadChannel
 
size() - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
size() - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
size() - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
size() - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
 
size() - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
SIZE_OF_UNCOMPRESSED_LENGTH - Static variable in class org.apache.arrow.vector.compression.CompressionUtil
 
sizeOfValueBuffer() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
sizeOfValueBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
 
sizeOfValueBuffer() - Method in interface org.apache.arrow.vector.VariableWidthVector
Provide the number of bytes contained in the valueBuffer.
skip() - Method in class org.apache.arrow.maven.plugins.BaseModuleInfoCompilerPlugin
 
skip() - Method in class org.apache.arrow.maven.plugins.ModuleInfoCompilerPlugin
 
skip() - Method in class org.apache.arrow.maven.plugins.ModuleInfoTestCompilerPlugin
 
skip(int) - Method in class org.apache.arrow.vector.ipc.JsonFileReader
Skips a number of record batches in the file.
SkipConsumer - Class in org.apache.arrow.consumers
Consumer which skip (throw away) data from the decoder.
SkipConsumer(SkipFunction) - Constructor for class org.apache.arrow.consumers.SkipConsumer
 
SkipFunction - Interface in org.apache.arrow.consumers
Adapter function to skip (throw away) data from the decoder.
skippable() - Method in interface org.apache.arrow.consumers.Consumer
Indicates whether the consumer is type of SkipConsumer.
skippable() - Method in class org.apache.arrow.consumers.SkipConsumer
 
slice() - Method in class io.netty.buffer.NettyArrowBuf
 
slice(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
slice() - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
slice(int, int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
slice() - Method in class org.apache.arrow.memory.ArrowBuf
Returns a slice of only the readable bytes in the buffer.
slice(long, long) - Method in class org.apache.arrow.memory.ArrowBuf
Returns a slice (view) starting at index with the given length.
slice(int) - Method in class org.apache.arrow.vector.table.Table
Slice this table from desired index.
slice(int, int) - Method in class org.apache.arrow.vector.table.Table
Slice this table at desired index and length.
slice(int) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Slice this root from desired index.
slice(int, int) - Method in class org.apache.arrow.vector.VectorSchemaRoot
Slice this root at desired index and length.
smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
smallInt() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
smallInt() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
smallInt(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
SmallIntBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for 8-bit integers.
SmallIntBinder(SmallIntVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.SmallIntBinder
 
SmallIntBinder(SmallIntVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.SmallIntBinder
 
SmallIntConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume smallInt type values from ResultSet.
SmallIntConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.SmallIntConsumer
 
SmallIntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
SmallIntHolder() - Constructor for class org.apache.arrow.vector.holders.SmallIntHolder
 
SmallIntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
SmallIntHolderReaderImpl(SmallIntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
 
SmallIntReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
SmallIntReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
SmallIntReaderImpl(SmallIntVector) - Constructor for class org.apache.arrow.vector.complex.impl.SmallIntReaderImpl
 
SmallIntVector - Class in org.apache.arrow.vector
SmallIntVector implements a fixed width (2 bytes) vector of short values which could be null.
SmallIntVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.SmallIntVector
Instantiate a SmallIntVector.
SmallIntVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.SmallIntVector
Instantiate a SmallIntVector.
SmallIntVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.SmallIntVector
Instantiate a SmallIntVector.
SmallIntWriter - Interface in org.apache.arrow.vector.complex.writer
 
SmallIntWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
SmallIntWriterImpl(SmallIntVector) - Constructor for class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
socket - Variable in class org.apache.arrow.tools.EchoServer.ClientConnection
 
sort(V, IntVector, VectorValueComparator<V>) - Method in class org.apache.arrow.algorithm.sort.IndexSorter
Sorts indices, by quick-sort.
sortInPlace(V, VectorValueComparator<V>) - Method in class org.apache.arrow.algorithm.sort.FixedWidthInPlaceVectorSorter
 
sortInPlace(V, VectorValueComparator<V>) - Method in interface org.apache.arrow.algorithm.sort.InPlaceVectorSorter
Sort a vector in-place.
sortOutOfPlace(V, V, VectorValueComparator<V>) - Method in class org.apache.arrow.algorithm.sort.FixedWidthOutOfPlaceVectorSorter
 
sortOutOfPlace(V, V, VectorValueComparator<V>) - Method in class org.apache.arrow.algorithm.sort.GeneralOutOfPlaceVectorSorter
 
sortOutOfPlace(V, V, VectorValueComparator<V>) - Method in interface org.apache.arrow.algorithm.sort.OutOfPlaceVectorSorter
Sort a vector out-of-place.
sortOutOfPlace(V, V, VectorValueComparator<V>) - Method in class org.apache.arrow.algorithm.sort.VariableWidthOutOfPlaceVectorSorter
 
Sparse - Static variable in class org.apache.arrow.flatbuf.UnionMode
 
sparseIndex(Table) - Method in class org.apache.arrow.flatbuf.SparseTensor
Sparse tensor index
sparseIndexType() - Method in class org.apache.arrow.flatbuf.SparseTensor
 
SparseMatrixCompressedAxis - Class in org.apache.arrow.flatbuf
 
SparseMatrixIndexCSX - Class in org.apache.arrow.flatbuf
Compressed Sparse format, that is matrix-specific.
SparseMatrixIndexCSX() - Constructor for class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
SparseMatrixIndexCSX - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
 
SparseMatrixIndexCSX.Vector - Class in org.apache.arrow.flatbuf
 
SparseTensor - Static variable in class org.apache.arrow.flatbuf.MessageHeader
 
SparseTensor - Class in org.apache.arrow.flatbuf
 
SparseTensor() - Constructor for class org.apache.arrow.flatbuf.SparseTensor
 
SparseTensor.Vector - Class in org.apache.arrow.flatbuf
 
SparseTensorIndex - Class in org.apache.arrow.flatbuf
 
SparseTensorIndexCOO - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
 
SparseTensorIndexCOO - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- EXPERIMENTAL: Data structures for sparse tensors Coordinate (COO) format of sparse tensor index.
SparseTensorIndexCOO() - Constructor for class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
SparseTensorIndexCOO.Vector - Class in org.apache.arrow.flatbuf
 
SparseTensorIndexCSF - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
 
SparseTensorIndexCSF - Class in org.apache.arrow.flatbuf
Compressed Sparse Fiber (CSF) sparse tensor index.
SparseTensorIndexCSF() - Constructor for class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
SparseTensorIndexCSF.Vector - Class in org.apache.arrow.flatbuf
 
splitAndTransfer(int, int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector.StructTransferPair
 
splitAndTransfer(int, int) - Method in class org.apache.arrow.vector.complex.StructVector.NullableStructTransferPair
 
splitAndTransfer(int, int) - Method in class org.apache.arrow.vector.TimeStampVector.TransferImpl
 
splitAndTransfer(int, int) - Method in interface org.apache.arrow.vector.util.TransferPair
 
splitAndTransferTo(int, int, BaseFixedWidthVector) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Slice this vector at desired index and length and transfer the corresponding data to the target vector.
splitAndTransferTo(int, int, BaseLargeVariableWidthVector) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Slice this vector at desired index and length and transfer the corresponding data to the target vector.
splitAndTransferTo(int, int, BaseVariableWidthVector) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Slice this vector at desired index and length and transfer the corresponding data to the target vector.
splitAndTransferTo(int, int, BaseFixedWidthVector) - Method in class org.apache.arrow.vector.BitVector
Slice this vector at desired index and length and transfer the corresponding data to the target vector.
SQL_ALL_TABLES_ARE_SELECTABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether all tables are selectable.
SQL_ANSI92_SUPPORTED_LEVEL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported ANSI92 SQL grammar level.
SQL_BATCH_UPDATES_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether this database supports batch updates.
SQL_CASE_SENSITIVITY_CASE_INSENSITIVE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
SQL_CASE_SENSITIVITY_CASE_INSENSITIVE = 1;
SQL_CASE_SENSITIVITY_LOWERCASE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
SQL_CASE_SENSITIVITY_LOWERCASE = 3;
SQL_CASE_SENSITIVITY_UNKNOWN_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
SQL_CASE_SENSITIVITY_UNKNOWN = 0;
SQL_CASE_SENSITIVITY_UPPERCASE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
SQL_CASE_SENSITIVITY_UPPERCASE = 2;
SQL_CATALOG_AT_START_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether a catalog appears at the start of a fully qualified table name.
SQL_CATALOG_NAME_KEY - Static variable in class org.apache.arrow.adapter.jdbc.Constants
 
SQL_CATALOG_TERM_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with the preferred term for "catalog".
SQL_CATALOGS_SUPPORTED_ACTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported actions for a SQL schema.
SQL_COLUMN_NAME_KEY - Static variable in class org.apache.arrow.adapter.jdbc.Constants
 
SQL_CONVERT_BIGINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_BIGINT = 0;
SQL_CONVERT_BINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_BINARY = 1;
SQL_CONVERT_BIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_BIT = 2;
SQL_CONVERT_CHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_CHAR = 3;
SQL_CONVERT_DATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_DATE = 4;
SQL_CONVERT_DECIMAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_DECIMAL = 5;
SQL_CONVERT_FLOAT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_FLOAT = 6;
SQL_CONVERT_INTEGER_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_INTEGER = 7;
SQL_CONVERT_INTERVAL_DAY_TIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_INTERVAL_DAY_TIME = 8;
SQL_CONVERT_INTERVAL_YEAR_MONTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_INTERVAL_YEAR_MONTH = 9;
SQL_CONVERT_LONGVARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_LONGVARBINARY = 10;
SQL_CONVERT_LONGVARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_LONGVARCHAR = 11;
SQL_CONVERT_NUMERIC_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_NUMERIC = 12;
SQL_CONVERT_REAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_REAL = 13;
SQL_CONVERT_SMALLINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_SMALLINT = 14;
SQL_CONVERT_TIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_TIME = 15;
SQL_CONVERT_TIMESTAMP_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_TIMESTAMP = 16;
SQL_CONVERT_TINYINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_TINYINT = 17;
SQL_CONVERT_VARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_VARBINARY = 18;
SQL_CONVERT_VARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
SQL_CONVERT_VARCHAR = 19;
SQL_CORE_GRAMMAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
SQL_CORE_GRAMMAR = 1;
SQL_CORRELATED_SUBQUERIES_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether correlated subqueries are supported.
SQL_DATA_DEFINITION_CAUSES_TRANSACTION_COMMIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether a data definition statement within a transaction forces the transaction to commit.
SQL_DATA_DEFINITION_TRANSACTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
SQL_DATA_DEFINITION_TRANSACTIONS = 1;
SQL_DATA_DEFINITIONS_IN_TRANSACTIONS_IGNORED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether a data definition statement within a transaction is ignored.
SQL_DATA_MANIPULATION_TRANSACTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
SQL_DATA_MANIPULATION_TRANSACTIONS = 2;
SQL_DATETIME_FUNCTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string list with values of the supported datetime functions.
SQL_DB_SCHEMA_NAME_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed in a schema name.
SQL_DDL_CATALOG_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether the Flight SQL Server supports CREATE and DROP of catalogs.
SQL_DDL_SCHEMA_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether the Flight SQL Server supports CREATE and DROP of schemas.
SQL_DDL_TABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Indicates whether the Flight SQL Server supports CREATE and DROP of tables.
SQL_DEFAULT_TRANSACTION_ISOLATION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves this database's default transaction isolation level as described in `arrow.flight.protocol.sql.SqlTransactionIsolationLevel`.
SQL_ELEMENT_IN_INDEX_DEFINITIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
SQL_ELEMENT_IN_INDEX_DEFINITIONS = 1;
SQL_ELEMENT_IN_PRIVILEGE_DEFINITIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
SQL_ELEMENT_IN_PRIVILEGE_DEFINITIONS = 2;
SQL_ELEMENT_IN_PROCEDURE_CALLS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
SQL_ELEMENT_IN_PROCEDURE_CALLS = 0;
SQL_EXTENDED_GRAMMAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
SQL_EXTENDED_GRAMMAR = 2;
SQL_EXTRA_NAME_CHARACTERS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with all the "extra" characters that can be used in unquoted identifier names (those beyond a-z, A-Z, 0-9 and _).
SQL_FULL_OUTER_JOINS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
SQL_FULL_OUTER_JOINS = 2;
SQL_GROUP_BY_BEYOND_SELECT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
SQL_GROUP_BY_BEYOND_SELECT = 1;
SQL_GROUP_BY_UNRELATED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
SQL_GROUP_BY_UNRELATED = 0;
SQL_IDENTIFIER_CASE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int32 ordinal representing the case sensitivity of catalog, table, schema and table names.
SQL_IDENTIFIER_QUOTE_CHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with the supported character(s) used to surround a delimited identifier.
SQL_JOINS_UNSUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
SQL_JOINS_UNSUPPORTED = 0;
SQL_KEYWORDS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string list with values of the supported keywords.
SQL_LIMITED_OUTER_JOINS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
SQL_LIMITED_OUTER_JOINS = 1;
SQL_LOCATORS_UPDATE_COPY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether updates made to a LOB are made on a copy or directly to the LOB.
SQL_MAX_BINARY_LITERAL_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of hex characters allowed in an inline binary literal.
SQL_MAX_CATALOG_NAME_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed in a catalog name.
SQL_MAX_CHAR_LITERAL_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed for a character literal.
SQL_MAX_COLUMN_NAME_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed for a column name.
SQL_MAX_COLUMNS_IN_GROUP_BY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of columns allowed in a GROUP BY clause.
SQL_MAX_COLUMNS_IN_INDEX_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of columns allowed in an index.
SQL_MAX_COLUMNS_IN_ORDER_BY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of columns allowed in an ORDER BY clause.
SQL_MAX_COLUMNS_IN_SELECT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of columns allowed in a SELECT list.
SQL_MAX_COLUMNS_IN_TABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of columns allowed in a table.
SQL_MAX_CONNECTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of concurrent connections possible.
SQL_MAX_CURSOR_NAME_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value the maximum number of characters allowed in a cursor name.
SQL_MAX_INDEX_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of bytes allowed for an index, including all of the parts of the index.
SQL_MAX_PROCEDURE_NAME_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed in a procedure name.
SQL_MAX_ROW_SIZE_INCLUDES_BLOBS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean indicating whether the return value for the JDBC method getMaxRowSize includes the SQL data types LONGVARCHAR and LONGVARBINARY.
SQL_MAX_ROW_SIZE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of bytes allowed in a single row.
SQL_MAX_STATEMENT_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed for an SQL statement; a result of 0 (zero) means that there is no limit or the limit is not known.
SQL_MAX_STATEMENTS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of active statements that can be open at the same time.
SQL_MAX_TABLE_NAME_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed in a table name.
SQL_MAX_TABLES_IN_SELECT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of tables allowed in a SELECT statement.
SQL_MAX_USERNAME_LENGTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int64 value representing the maximum number of characters allowed in a user name.
SQL_MINIMUM_GRAMMAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
SQL_MINIMUM_GRAMMAR = 0;
SQL_NAMED_PARAMETERS_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether named parameters are supported in callable statements.
SQL_NULL_ORDERING_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the null ordering.
SQL_NULL_PLUS_NULL_IS_NULL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether concatenations between null and non-null values being null are supported.
SQL_NULLS_SORTED_AT_END_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
SQL_NULLS_SORTED_AT_END = 3;
SQL_NULLS_SORTED_AT_START_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
SQL_NULLS_SORTED_AT_START = 2;
SQL_NULLS_SORTED_HIGH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
SQL_NULLS_SORTED_HIGH = 0;
SQL_NULLS_SORTED_LOW_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
SQL_NULLS_SORTED_LOW = 1;
SQL_NUMERIC_FUNCTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string list with values of the supported numeric functions.
SQL_OUTER_JOINS_SUPPORT_LEVEL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the support level for SQL OUTER JOINs.
SQL_POSITIONED_DELETE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
SQL_POSITIONED_DELETE = 0;
SQL_POSITIONED_UPDATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
SQL_POSITIONED_UPDATE = 1;
SQL_PROCEDURE_TERM_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with the preferred term for "procedure".
SQL_QUOTED_IDENTIFIER_CASE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a int32 describing the case sensitivity of quoted identifiers.
SQL_RESULT_SET_CONCURRENCY_READ_ONLY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
SQL_RESULT_SET_CONCURRENCY_READ_ONLY = 1;
SQL_RESULT_SET_CONCURRENCY_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
SQL_RESULT_SET_CONCURRENCY_UNSPECIFIED = 0;
SQL_RESULT_SET_CONCURRENCY_UPDATABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
SQL_RESULT_SET_CONCURRENCY_UPDATABLE = 2;
SQL_RESULT_SET_TYPE_FORWARD_ONLY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
SQL_RESULT_SET_TYPE_FORWARD_ONLY = 1;
SQL_RESULT_SET_TYPE_SCROLL_INSENSITIVE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
SQL_RESULT_SET_TYPE_SCROLL_INSENSITIVE = 2;
SQL_RESULT_SET_TYPE_SCROLL_SENSITIVE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
SQL_RESULT_SET_TYPE_SCROLL_SENSITIVE = 3;
SQL_RESULT_SET_TYPE_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
SQL_RESULT_SET_TYPE_UNSPECIFIED = 0;
SQL_SAVEPOINTS_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether this database supports savepoints.
SQL_SCHEMA_NAME_KEY - Static variable in class org.apache.arrow.adapter.jdbc.Constants
 
SQL_SCHEMA_TERM_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string with the preferred term for "schema".
SQL_SCHEMAS_SUPPORTED_ACTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported actions for a SQL schema.
SQL_SEARCH_STRING_ESCAPE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the UTF-8 string that can be used to escape wildcard characters.
SQL_SELECT_FOR_UPDATE_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether SELECT FOR UPDATE statements are supported.
SQL_STORED_FUNCTIONS_USING_CALL_SYNTAX_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether invoking user-defined or vendor functions using the stored procedure escape syntax is supported.
SQL_STORED_PROCEDURES_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether stored procedure calls that use the stored procedure escape syntax are supported.
SQL_STRING_FUNCTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string list with values of the supported string functions.
SQL_SUBQUERIES_IN_COMPARISONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
SQL_SUBQUERIES_IN_COMPARISONS = 0;
SQL_SUBQUERIES_IN_EXISTS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
SQL_SUBQUERIES_IN_EXISTS = 1;
SQL_SUBQUERIES_IN_INS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
SQL_SUBQUERIES_IN_INS = 2;
SQL_SUBQUERIES_IN_QUANTIFIEDS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
SQL_SUBQUERIES_IN_QUANTIFIEDS = 3;
SQL_SUPPORTED_CONCURRENCIES_FOR_RESULT_SET_FORWARD_ONLY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Returns an int32 bitmask value concurrency types supported for `arrow.flight.protocol.sql.SqlSupportedResultSetType.SQL_RESULT_SET_TYPE_FORWARD_ONLY`.
SQL_SUPPORTED_CONCURRENCIES_FOR_RESULT_SET_SCROLL_INSENSITIVE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Returns an int32 bitmask value concurrency types supported for `arrow.flight.protocol.sql.SqlSupportedResultSetType.SQL_RESULT_SET_TYPE_SCROLL_INSENSITIVE`.
SQL_SUPPORTED_CONCURRENCIES_FOR_RESULT_SET_SCROLL_SENSITIVE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Returns an int32 bitmask value concurrency types supported for `arrow.flight.protocol.sql.SqlSupportedResultSetType.SQL_RESULT_SET_TYPE_SCROLL_SENSITIVE`.
SQL_SUPPORTED_CONCURRENCIES_FOR_RESULT_SET_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Returns an int32 bitmask value concurrency types supported for `arrow.flight.protocol.sql.SqlSupportedResultSetType.SQL_RESULT_SET_TYPE_UNSPECIFIED`.
SQL_SUPPORTED_GRAMMAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported SQL grammar level as per the ODBC specification.
SQL_SUPPORTED_GROUP_BY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported GROUP BY commands; Returns an int32 bitmask value representing the supported commands.
SQL_SUPPORTED_POSITIONED_COMMANDS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported SQL positioned commands.
SQL_SUPPORTED_RESULT_SET_TYPES_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves an int32 bitmask value representing the supported result set types.
SQL_SUPPORTED_SUBQUERIES_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported SQL subqueries.
SQL_SUPPORTED_TRANSACTION_NONE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
Unknown/not indicated/no support
SQL_SUPPORTED_TRANSACTION_SAVEPOINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
Transactions and savepoints
SQL_SUPPORTED_TRANSACTION_TRANSACTION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
Transactions, but not savepoints.
SQL_SUPPORTED_TRANSACTIONS_ISOLATION_LEVELS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported transactions isolation levels.
SQL_SUPPORTED_UNIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves the supported SQL UNIONs.
SQL_SUPPORTS_COLUMN_ALIASING_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether column aliasing is supported.
SQL_SUPPORTS_CONVERT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a map where the key is the type to convert from and the value is a list with the types to convert to, indicating the supported conversions.
SQL_SUPPORTS_DIFFERENT_TABLE_CORRELATION_NAMES_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether, when table correlation names are supported, they are restricted to being different from the names of the tables.
SQL_SUPPORTS_EXPRESSIONS_IN_ORDER_BY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether expressions in ORDER BY lists are supported.
SQL_SUPPORTS_INTEGRITY_ENHANCEMENT_FACILITY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether the SQL Integrity Enhancement Facility is supported.
SQL_SUPPORTS_LIKE_ESCAPE_CLAUSE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether specifying a LIKE escape clause is supported.
SQL_SUPPORTS_NON_NULLABLE_COLUMNS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether columns may be defined as non-nullable.
SQL_SUPPORTS_ORDER_BY_UNRELATED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether using a column that is not in the SELECT statement in a GROUP BY clause is supported.
SQL_SUPPORTS_TABLE_CORRELATION_NAMES_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether, when table correlation names are supported, they are restricted to being different from the names of the tables.
SQL_SYSTEM_FUNCTIONS_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a UTF-8 string list with values of the supported system functions.
SQL_TABLE_NAME_KEY - Static variable in class org.apache.arrow.adapter.jdbc.Constants
 
SQL_TRANSACTION_NONE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
SQL_TRANSACTION_NONE = 0;
SQL_TRANSACTION_READ_COMMITTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
SQL_TRANSACTION_READ_COMMITTED = 2;
SQL_TRANSACTION_READ_UNCOMMITTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
SQL_TRANSACTION_READ_UNCOMMITTED = 1;
SQL_TRANSACTION_REPEATABLE_READ_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
SQL_TRANSACTION_REPEATABLE_READ = 3;
SQL_TRANSACTION_SERIALIZABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
SQL_TRANSACTION_SERIALIZABLE = 4;
SQL_TRANSACTION_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
SQL_TRANSACTION_UNSPECIFIED = 0;
SQL_TRANSACTIONS_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Retrieves a boolean value indicating whether transactions are supported.
SQL_TYPE_KEY - Static variable in class org.apache.arrow.adapter.jdbc.Constants
 
SQL_UNION_ALL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
SQL_UNION_ALL = 1;
SQL_UNION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
SQL_UNION = 0;
SqlInfoBuilder - Class in org.apache.arrow.flight.sql
SqlInfoBuilder() - Constructor for class org.apache.arrow.flight.sql.SqlInfoBuilder
 
SqlInfoOptionsUtils - Class in org.apache.arrow.flight.sql.util
sqlToArrowVectorIterator(ResultSet, BufferAllocator) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrow
For the given JDBC ResultSet, fetch the data from Relational DB and convert it to Arrow objects.
sqlToArrowVectorIterator(ResultSet, JdbcToArrowConfig) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrow
For the given JDBC ResultSet, fetch the data from Relational DB and convert it to Arrow objects.
SqlTypes - Class in org.apache.arrow.driver.jdbc.utils
SQL Types utility functions.
SqlTypes() - Constructor for class org.apache.arrow.driver.jdbc.utils.SqlTypes
 
StableVectorComparator<V extends ValueVector> - Class in org.apache.arrow.algorithm.sort
Stable sorter.
StableVectorComparator(VectorValueComparator<V>) - Constructor for class org.apache.arrow.algorithm.sort.StableVectorComparator
Constructs a stable comparator from a given comparator.
StackTrace - Class in org.apache.arrow.memory.util
Convenient way of obtaining and manipulating stack traces for debugging.
StackTrace() - Constructor for class org.apache.arrow.memory.util.StackTrace
Constructor.
start() - Method in class org.apache.arrow.flight.FlightServer
Start the server.
start(VectorSchemaRoot) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Start sending data, using the schema of the given VectorSchemaRoot.
start(VectorSchemaRoot, DictionaryProvider) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Start sending data, using the schema of the given VectorSchemaRoot.
start(VectorSchemaRoot, DictionaryProvider, IpcOption) - Method in interface org.apache.arrow.flight.OutboundStreamListener
Start sending data, using the schema of the given VectorSchemaRoot.
start() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
start() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
start() - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
start() - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
Start writing to either the list or the struct.
start() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
start() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
start() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
start() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
start() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
start() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
start - Variable in class org.apache.arrow.vector.holders.Decimal256Holder
 
start - Variable in class org.apache.arrow.vector.holders.DecimalHolder
 
start - Variable in class org.apache.arrow.vector.holders.LargeVarBinaryHolder
 
start - Variable in class org.apache.arrow.vector.holders.LargeVarCharHolder
 
start - Variable in class org.apache.arrow.vector.holders.NullableDecimal256Holder
 
start - Variable in class org.apache.arrow.vector.holders.NullableDecimalHolder
 
start - Variable in class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
 
start - Variable in class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
 
start - Variable in class org.apache.arrow.vector.holders.NullableVarBinaryHolder
 
start - Variable in class org.apache.arrow.vector.holders.NullableVarCharHolder
 
start - Variable in class org.apache.arrow.vector.holders.RepeatedListHolder
 
start - Variable in class org.apache.arrow.vector.holders.RepeatedStructHolder
 
start - Variable in class org.apache.arrow.vector.holders.VarBinaryHolder
 
start - Variable in class org.apache.arrow.vector.holders.VarCharHolder
 
start() - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
start() - Method in class org.apache.arrow.vector.ipc.JsonFileReader
Reads the beginning (schema section) of the json file and returns it.
start(Schema, DictionaryProvider) - Method in class org.apache.arrow.vector.ipc.JsonFileWriter
Writes out the "header" of the file including the schema and any dictionaries required.
START_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
startAxisOrderVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
startBinary(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Binary
 
startBinaryView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.BinaryView
 
startBodyCompression(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
startBool(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Bool
 
startBuffersVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
startChildrenVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Field
 
startCustomMetadataVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Field
 
startCustomMetadataVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
startCustomMetadataVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Message
 
startCustomMetadataVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
startDate(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Date
 
startDecimal(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Decimal
 
startDictionariesVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
startDictionaryBatch(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
startDictionaryEncoding(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
startDuration(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Duration
 
startEntry() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
Start a map entry that should be followed by calls to UnionMapWriter.key() and UnionMapWriter.value() writers.
startEntry() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
startEntry() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.MapWriter
 
startFeaturesVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
startField(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Field
 
startFieldsVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Schema
 
startFixedSizeBinary(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
startFixedSizeList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.FixedSizeList
 
startFloatingPoint(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.FloatingPoint
 
startFooter(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Footer
 
startIndicesBuffersVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
startIndicesStridesVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
startIndptrBuffersVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
startInt(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Int
 
startInternal(WriteChannel) - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
 
startInternal(WriteChannel) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
startInterval(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Interval
 
startKeyValue(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.KeyValue
 
startLargeBinary(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeBinary
 
startLargeList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeList
 
startLargeListView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeListView
 
startLargeUtf8(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.LargeUtf8
 
startList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.List
 
startList() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
startList() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
startList() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
startList() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
startList() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
startList() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
startListView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.ListView
 
startMap(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Map
 
startMap() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
Start writing a map that consists of 1 or more entries.
startMap() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
startMap() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.MapWriter
 
startMessage(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Message
 
startNewValue(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
Starts a new repeated value.
startNewValue(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
Start a new value in the list vector.
startNewValue(long) - Method in class org.apache.arrow.vector.complex.LargeListVector
Start a new value in the list vector.
startNewValue(int) - Method in class org.apache.arrow.vector.complex.ListVector
Start a new value in the list vector.
startNodesVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
startNull(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Null
 
startPut(FlightDescriptor, VectorSchemaRoot, FlightClient.PutListener, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Create or append a descriptor with another stream.
startPut(FlightDescriptor, VectorSchemaRoot, DictionaryProvider, FlightClient.PutListener, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Create or append a descriptor with another stream.
startPut(FlightDescriptor, FlightClient.PutListener, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
Create or append a descriptor with another stream.
startRecordBatch(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
startRecordBatchesVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Footer
 
startRunEndEncoded(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.RunEndEncoded
 
startSchema(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Schema
 
startShapeVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
startShapeVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
startSparseMatrixIndexCSX(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
startSparseTensor(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
startSparseTensorIndexCOO(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
startSparseTensorIndexCSF(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
startStridesVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Tensor
 
startStruct_(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Struct_
 
startTensor(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Tensor
 
startTensorDim(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.TensorDim
 
startTime(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Time
 
startTimestamp(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Timestamp
 
startTypeIdsVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.Union
 
startUnion(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Union
 
startUtf8(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Utf8
 
startUtf8View(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Utf8View
 
startVariadicBufferCountsVector(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
STATEMENT_HANDLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
StateTool - Class in org.apache.arrow.vector.complex
Utility methods for state machines based on enums.
status() - Method in exception org.apache.arrow.flight.FlightRuntimeException
 
STATUS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
StatusUtils - Class in org.apache.arrow.flight.grpc
Utilities to adapt gRPC and Flight status objects.
storageType() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
The on-wire type for this user-defined type.
STREAM_COUNT_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
StreamToFile - Class in org.apache.arrow.tools
Converts an Arrow stream to an Arrow file.
StreamToFile() - Constructor for class org.apache.arrow.tools.StreamToFile
 
strides(int) - Method in class org.apache.arrow.flatbuf.Tensor
Non-negative byte offsets to advance one value cell along each dimension If omitted, default to row-major order (C-like).
stridesAsByteBuffer() - Method in class org.apache.arrow.flatbuf.Tensor
 
stridesInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.Tensor
 
stridesLength() - Method in class org.apache.arrow.flatbuf.Tensor
 
stridesVector() - Method in class org.apache.arrow.flatbuf.Tensor
 
stridesVector(LongVector) - Method in class org.apache.arrow.flatbuf.Tensor
 
struct() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
struct() - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.NullReader
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
struct - Variable in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
Creates a new writer for a struct with the given name.
struct() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
struct() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
struct() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
struct() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
struct() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
struct() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
struct(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
struct(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
Struct() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
Struct_ - Class in org.apache.arrow.flatbuf
A Struct_ in the flatbuffer metadata is the same as an Arrow Struct (according to the physical memory layout).
Struct_() - Constructor for class org.apache.arrow.flatbuf.Struct_
 
Struct_ - Static variable in class org.apache.arrow.flatbuf.Type
 
Struct_.Vector - Class in org.apache.arrow.flatbuf
 
StructAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Struct Arrow types.
StructAvaticaParameterConverter(ArrowType.Struct) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.StructAvaticaParameterConverter
 
StructOrListWriterImpl - Class in org.apache.arrow.vector.complex.impl
Concrete implementation of BaseWriter.StructOrListWriter.
StructOrListWriterImpl(BaseWriter.StructWriter) - Constructor for class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
Constructs a new instance using a BaseWriter.StructWriter (instead of an BaseWriter.ListWriter).
StructOrListWriterImpl(BaseWriter.ListWriter) - Constructor for class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
Constructs a new instance using a BaseWriter.ListWriter (instead of a BaseWriter.StructWriter).
StructSubfieldEncoder - Class in org.apache.arrow.vector.dictionary
Sub fields encoder/decoder for Dictionary encoded StructVector.
StructSubfieldEncoder(BufferAllocator, DictionaryProvider.MapDictionaryProvider) - Constructor for class org.apache.arrow.vector.dictionary.StructSubfieldEncoder
Construct an instance.
StructSubfieldEncoder(BufferAllocator, DictionaryProvider.MapDictionaryProvider, ArrowBufHasher) - Constructor for class org.apache.arrow.vector.dictionary.StructSubfieldEncoder
Construct an instance.
StructTransferPair(NonNullableStructVector, NonNullableStructVector) - Constructor for class org.apache.arrow.vector.complex.NonNullableStructVector.StructTransferPair
 
StructTransferPair(NonNullableStructVector, NonNullableStructVector, boolean) - Constructor for class org.apache.arrow.vector.complex.NonNullableStructVector.StructTransferPair
 
StructVector - Class in org.apache.arrow.vector.complex
A Struct vector consists of nullability/validity buffer and children vectors that make up the struct's fields.
StructVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.StructVector
Constructs a new instance.
StructVector(String, BufferAllocator, FieldType, CallBack, AbstractStructVector.ConflictPolicy, boolean) - Constructor for class org.apache.arrow.vector.complex.StructVector
Constructs a new instance.
StructVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.StructVector
Constructs a new instance.
StructVector(Field, BufferAllocator, CallBack, AbstractStructVector.ConflictPolicy, boolean) - Constructor for class org.apache.arrow.vector.complex.StructVector
Constructs a new instance.
StructVector.NullableStructTransferPair - Class in org.apache.arrow.vector.complex
TransferPair for this (nullable) StructVector.
submit(Callable<T>) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
submit(Runnable, T) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
submit(Runnable) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
 
SUBSTRAIT_PLAN - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
SUBSTRAIT_PLAN_TEXT - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
SUBSTRAIT_VERSION - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
SubstraitPlan(byte[], String) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.SubstraitPlan
 
supportsANSI92EntryLevelSQL() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsANSI92FullSQL() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsANSI92IntermediateSQL() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsBatchUpdates() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsCatalogsInIndexDefinitions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsCatalogsInPrivilegeDefinitions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsColumnAliasing() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsConvert() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsConvert(int, int) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsCoreSQLGrammar() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsCorrelatedSubqueries() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsDifferentTableCorrelationNames() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsDirectRead() - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
supportsDirectRead() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
 
supportsExpressionsInOrderBy() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsExtendedSQLGrammar() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsFullOuterJoins() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsGroupBy() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsGroupByUnrelated() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsIntegrityEnhancementFacility() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsLikeEscapeClause() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsLimitedOuterJoins() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsMinimumSQLGrammar() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsNamedParameters() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsNonNullableColumns() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsOrderByUnrelated() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsOuterJoins() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsPositionedDelete() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsPositionedUpdate() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsResultSetType(int) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSavepoints() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSchemasInIndexDefinitions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSchemasInPrivilegeDefinitions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSchemasInProcedureCalls() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSelectForUpdate() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsStoredFunctionsUsingCallSyntax() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsStoredProcedures() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSubqueriesInComparisons() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSubqueriesInExists() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSubqueriesInIns() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsSubqueriesInQuantifieds() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsTableCorrelationNames() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsTransactionIsolationLevel(int) - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsTransactions() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsUnion() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
supportsUnionAll() - Method in class org.apache.arrow.driver.jdbc.ArrowDatabaseMetadata
 
SyncPutListener - Class in org.apache.arrow.flight
A listener for server-sent application metadata messages during a Flight DoPut.
SyncPutListener() - Constructor for class org.apache.arrow.flight.SyncPutListener
 
syncResults(Meta.StatementHandle, QueryState, long) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightMetaImpl
 
syncSchema() - Method in class org.apache.arrow.vector.VectorSchemaRoot
Synchronizes the schema from the current vectors.

T

table - Variable in class org.apache.arrow.vector.table.Row
The table we're enumerating.
Table - Class in org.apache.arrow.vector.table
Table is an immutable tabular data structure.
Table(Iterable<FieldVector>) - Constructor for class org.apache.arrow.vector.table.Table
Constructs new instance containing each of the given vectors.
Table(List<FieldVector>) - Constructor for class org.apache.arrow.vector.table.Table
Constructs a new instance with the number of rows set to the value count of the first FieldVector.
Table(List<FieldVector>, int) - Constructor for class org.apache.arrow.vector.table.Table
Constructs a new instance.
Table(List<FieldVector>, int, DictionaryProvider) - Constructor for class org.apache.arrow.vector.table.Table
Constructs a new instance.
Table(VectorSchemaRoot) - Constructor for class org.apache.arrow.vector.table.Table
Constructs a new instance containing the data from the argument.
TABLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
TABLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
TABLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
TABLE_NAME_FILTER_PATTERN_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
TABLE_TYPES_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
tableName(String) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets the table name.
TableRef - Class in org.apache.arrow.flight.sql.util
A helper class to reference a table to be passed to the flight sql client.
TableRef(String, String, String) - Constructor for class org.apache.arrow.flight.sql.util.TableRef
The complete constructor for the TableRef class.
takeDictionaryOwnership() - Method in class org.apache.arrow.flight.FlightStream
Get an owned reference to the dictionaries in this stream.
Tensor - Static variable in class org.apache.arrow.flatbuf.MessageHeader
 
Tensor - Class in org.apache.arrow.flatbuf
 
Tensor() - Constructor for class org.apache.arrow.flatbuf.Tensor
 
Tensor.Vector - Class in org.apache.arrow.flatbuf
 
TensorDim - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- Data structures for dense tensors Shape data for a single axis in a tensor
TensorDim() - Constructor for class org.apache.arrow.flatbuf.TensorDim
 
TensorDim.Vector - Class in org.apache.arrow.flatbuf
 
Test - Class in org.apache.arrow.flight
 
test(Empty, StreamObserver<Empty>) - Method in interface org.apache.arrow.flight.TestServiceGrpc.AsyncService
 
test(Empty) - Method in class org.apache.arrow.flight.TestServiceGrpc.TestServiceBlockingStub
 
test(Empty) - Method in class org.apache.arrow.flight.TestServiceGrpc.TestServiceFutureStub
 
test(Empty, StreamObserver<Empty>) - Method in class org.apache.arrow.flight.TestServiceGrpc.TestServiceStub
 
TestServiceGrpc - Class in org.apache.arrow.flight
 
TestServiceGrpc.AsyncService - Interface in org.apache.arrow.flight
 
TestServiceGrpc.TestServiceBlockingStub - Class in org.apache.arrow.flight
A stub to allow clients to do synchronous rpc calls to service TestService.
TestServiceGrpc.TestServiceFutureStub - Class in org.apache.arrow.flight
A stub to allow clients to do ListenableFuture-style rpc calls to service TestService.
TestServiceGrpc.TestServiceImplBase - Class in org.apache.arrow.flight
Base class for the server implementation of the service TestService.
TestServiceGrpc.TestServiceStub - Class in org.apache.arrow.flight
A stub to allow clients to do asynchronous rpc calls to service TestService.
TestServiceImplBase() - Constructor for class org.apache.arrow.flight.TestServiceGrpc.TestServiceImplBase
 
Text - Class in org.apache.arrow.vector.util
A simplified byte wrapper similar to Hadoop's Text class without all the dependencies.
Text() - Constructor for class org.apache.arrow.vector.util.Text
 
Text(String) - Constructor for class org.apache.arrow.vector.util.Text
Construct from a string.
Text(Text) - Constructor for class org.apache.arrow.vector.util.Text
Construct from another text.
Text(byte[]) - Constructor for class org.apache.arrow.vector.util.Text
Construct from a byte array.
Text.TextSerializer - Class in org.apache.arrow.vector.util
JSON serializer for Text.
TextSerializer() - Constructor for class org.apache.arrow.vector.util.Text.TextSerializer
 
thisUsesUnstableApi() - Method in class org.apache.arrow.flight.grpc.CallCredentialAdapter
 
threadPoolSize() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the thread pool size.
Ticket - Class in org.apache.arrow.flight
Endpoint for a particular stream.
Ticket(byte[]) - Constructor for class org.apache.arrow.flight.Ticket
 
TICKET_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
TICKET_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.Ticket
 
Time - Class in org.apache.arrow.flatbuf
Time is either a 32-bit or 64-bit signed integer type representing an elapsed time since midnight, stored in either of four units: seconds, milliseconds, microseconds or nanoseconds.
Time() - Constructor for class org.apache.arrow.flatbuf.Time
 
Time - Static variable in class org.apache.arrow.flatbuf.Type
 
Time(TimeUnit, int) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
Time.Vector - Class in org.apache.arrow.flatbuf
 
Time32Binder - Class in org.apache.arrow.adapter.jdbc.binder
A binder for 32-bit time types.
Time32Binder(TimeSecVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time32Binder
 
Time32Binder(TimeMilliVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time32Binder
 
Time32Binder(TimeSecVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time32Binder
 
Time32Binder(TimeMilliVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time32Binder
 
Time64Binder - Class in org.apache.arrow.adapter.jdbc.binder
A binder for 64-bit time types.
Time64Binder(TimeMicroVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time64Binder
 
Time64Binder(TimeNanoVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time64Binder
 
Time64Binder(TimeMicroVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time64Binder
 
Time64Binder(TimeNanoVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time64Binder
 
TimeAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Time Arrow types.
TimeAvaticaParameterConverter(ArrowType.Time) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.TimeAvaticaParameterConverter
 
TimeConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume time type values from ResultSet.
TimeConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.TimeConsumer
 
TIMED_OUT - Static variable in class org.apache.arrow.flight.CallStatus
 
timeFormat - Static variable in class org.apache.arrow.vector.util.DateUtility
 
timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeMicro() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeMicro() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeMicro(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeMicroComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeMicroComparator
 
TimeMicroHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeMicroHolder() - Constructor for class org.apache.arrow.vector.holders.TimeMicroHolder
 
TimeMicroHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeMicroHolderReaderImpl(TimeMicroHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
 
TimeMicroReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeMicroReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeMicroReaderImpl(TimeMicroVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeMicroReaderImpl
 
TimeMicroVector - Class in org.apache.arrow.vector
TimeMicroVector implements a fixed width vector (8 bytes) of time (microsecond resolution) values which could be null.
TimeMicroVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeMicroVector
Instantiate a TimeMicroVector.
TimeMicroVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeMicroVector
Instantiate a TimeMicroVector.
TimeMicroVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeMicroVector
Instantiate a TimeMicroVector.
TimeMicroWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeMicroWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeMicroWriterImpl(TimeMicroVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeMilli() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeMilli() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeMilli(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeMilliComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeMilliComparator
 
TimeMilliHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeMilliHolder() - Constructor for class org.apache.arrow.vector.holders.TimeMilliHolder
 
TimeMilliHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeMilliHolderReaderImpl(TimeMilliHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
 
TimeMilliReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeMilliReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeMilliReaderImpl(TimeMilliVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeMilliReaderImpl
 
TimeMilliVector - Class in org.apache.arrow.vector
TimeMilliVector implements a fixed width (4 bytes) vector of time (millisecond resolution) values which could be null.
TimeMilliVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeMilliVector
Instantiate a TimeMilliVector.
TimeMilliVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeMilliVector
Instantiate a TimeMilliVector.
TimeMilliVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeMilliVector
Instantiate a TimeMilliVector.
TimeMilliWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeMilliWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeMilliWriterImpl(TimeMilliVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeNano() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeNano() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeNano(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeNanoComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeNanoComparator
 
TimeNanoHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeNanoHolder() - Constructor for class org.apache.arrow.vector.holders.TimeNanoHolder
 
TimeNanoHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeNanoHolderReaderImpl(TimeNanoHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
 
TimeNanoReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeNanoReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeNanoReaderImpl(TimeNanoVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeNanoReaderImpl
 
TimeNanoVector - Class in org.apache.arrow.vector
TimeNanoVector implements a fixed width vector (8 bytes) of time (nanosecond resolution) values which could be null.
TimeNanoVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeNanoVector
Instantiate a TimeNanoVector.
TimeNanoVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeNanoVector
Instantiate a TimeNanoVector.
TimeNanoVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeNanoVector
Instantiate a TimeNanoVector.
TimeNanoWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeNanoWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeNanoWriterImpl(TimeNanoVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
timeout(long, TimeUnit) - Static method in class org.apache.arrow.flight.CallOptions
 
timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeSec() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeSec() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeSec(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeSecComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeSecComparator
 
TimeSecHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeSecHolder() - Constructor for class org.apache.arrow.vector.holders.TimeSecHolder
 
TimeSecHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeSecHolderReaderImpl(TimeSecHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
 
TimeSecReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeSecReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeSecReaderImpl(TimeSecVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeSecReaderImpl
 
TimeSecVector - Class in org.apache.arrow.vector
TimeSecVector implements a fixed width (4 bytes) vector of time (seconds resolution) values which could be null.
TimeSecVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeSecVector
Instantiate a TimeSecVector.
TimeSecVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeSecVector
Instantiate a TimeSecVector.
TimeSecVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeSecVector
Instantiate a TimeSecVector.
TimeSecWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeSecWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeSecWriterImpl(TimeSecVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
Timestamp - Class in org.apache.arrow.flatbuf
Timestamp is a 64-bit signed integer representing an elapsed time since a fixed epoch, stored in either of four units: seconds, milliseconds, microseconds or nanoseconds, and is optionally annotated with a timezone.
Timestamp() - Constructor for class org.apache.arrow.flatbuf.Timestamp
 
Timestamp - Static variable in class org.apache.arrow.flatbuf.Type
 
Timestamp(TimeUnit, String) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
Timestamp.Vector - Class in org.apache.arrow.flatbuf
 
TimestampAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Timestamp Arrow types.
TimestampAvaticaParameterConverter(ArrowType.Timestamp) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.TimestampAvaticaParameterConverter
 
TimeStampBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for timestamps.
TimeStampBinder(TimeStampVector, Calendar) - Constructor for class org.apache.arrow.adapter.jdbc.binder.TimeStampBinder
Create a binder for a timestamp vector using the default JDBC type code.
TimeStampBinder(TimeStampVector, Calendar, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.TimeStampBinder
Create a binder for a timestamp vector.
TimeStampComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.TimeStampComparator
 
TimestampConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume timestamp type values from ResultSet.
TimestampConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.TimestampConsumer
 
timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMicro() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampMicro(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampMicroHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampMicroHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampMicroHolder
 
TimeStampMicroHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMicroHolderReaderImpl(TimeStampMicroHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
 
TimeStampMicroReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMicroReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMicroReaderImpl(TimeStampMicroVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMicroReaderImpl
 
timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMicroTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampMicroTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
timeStampMicroTZ(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampMicroTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampMicroTZHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampMicroTZHolder
 
TimeStampMicroTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMicroTZHolderReaderImpl(TimeStampMicroTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
 
TimeStampMicroTZReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMicroTZReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMicroTZReaderImpl(TimeStampMicroTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMicroTZReaderImpl
 
TimeStampMicroTZVector - Class in org.apache.arrow.vector
TimeStampMicroTZVector implements a fixed width vector (8 bytes) of timestamp (microsecond resolution) values which could be null.
TimeStampMicroTZVector(String, BufferAllocator, String) - Constructor for class org.apache.arrow.vector.TimeStampMicroTZVector
Instantiate a TimeStampMicroTZVector.
TimeStampMicroTZVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMicroTZVector
Instantiate a TimeStampMicroTZVector.
TimeStampMicroTZVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMicroTZVector
Instantiate a TimeStampMicroTZVector.
TimeStampMicroTZWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampMicroTZWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMicroTZWriterImpl(TimeStampMicroTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
TimeStampMicroVector - Class in org.apache.arrow.vector
TimeStampMicroVector implements a fixed width vector (8 bytes) of timestamp (microsecond resolution) values which could be null.
TimeStampMicroVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMicroVector
Instantiate a TimeStampMicroVector.
TimeStampMicroVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMicroVector
Instantiate a TimeStampMicroVector.
TimeStampMicroVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMicroVector
Instantiate a TimeStampMicroVector.
TimeStampMicroWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampMicroWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMicroWriterImpl(TimeStampMicroVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMilli() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampMilli(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampMilliHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampMilliHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampMilliHolder
 
TimeStampMilliHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMilliHolderReaderImpl(TimeStampMilliHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
 
TimeStampMilliReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMilliReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMilliReaderImpl(TimeStampMilliVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMilliReaderImpl
 
timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampMilliTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampMilliTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
timeStampMilliTZ(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampMilliTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampMilliTZHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampMilliTZHolder
 
TimeStampMilliTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMilliTZHolderReaderImpl(TimeStampMilliTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
 
TimeStampMilliTZReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMilliTZReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampMilliTZReaderImpl(TimeStampMilliTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMilliTZReaderImpl
 
TimeStampMilliTZVector - Class in org.apache.arrow.vector
TimeStampMilliTZVector implements a fixed width vector (8 bytes) of timestamp (millisecond resolution) values which could be null.
TimeStampMilliTZVector(String, BufferAllocator, String) - Constructor for class org.apache.arrow.vector.TimeStampMilliTZVector
Instantiate a TimeStampMilliTZVector.
TimeStampMilliTZVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMilliTZVector
Instantiate a TimeStampMilliTZVector.
TimeStampMilliTZVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMilliTZVector
Instantiate a TimeStampMilliTZVector.
TimeStampMilliTZWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampMilliTZWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMilliTZWriterImpl(TimeStampMilliTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
TimeStampMilliVector - Class in org.apache.arrow.vector
TimeStampMilliVector implements a fixed width vector (8 bytes) of timestamp (millisecond resolution) values which could be null.
TimeStampMilliVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMilliVector
Instantiate a TimeStampMilliVector.
TimeStampMilliVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMilliVector
Instantiate a TimeStampMilliVector.
TimeStampMilliVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampMilliVector
Instantiate a TimeStampMilliVector.
TimeStampMilliWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampMilliWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampMilliWriterImpl(TimeStampMilliVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampNano() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampNano(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampNanoHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampNanoHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampNanoHolder
 
TimeStampNanoHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampNanoHolderReaderImpl(TimeStampNanoHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
 
TimeStampNanoReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampNanoReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampNanoReaderImpl(TimeStampNanoVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampNanoReaderImpl
 
timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampNanoTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampNanoTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
timeStampNanoTZ(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampNanoTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampNanoTZHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampNanoTZHolder
 
TimeStampNanoTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampNanoTZHolderReaderImpl(TimeStampNanoTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
 
TimeStampNanoTZReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampNanoTZReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampNanoTZReaderImpl(TimeStampNanoTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampNanoTZReaderImpl
 
TimeStampNanoTZVector - Class in org.apache.arrow.vector
TimeStampNanoTZVector implements a fixed width vector (8 bytes) of timestamp (nanosecond resolution) values which could be null.
TimeStampNanoTZVector(String, BufferAllocator, String) - Constructor for class org.apache.arrow.vector.TimeStampNanoTZVector
Instantiate a TimeStampNanoTZVector.
TimeStampNanoTZVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampNanoTZVector
Instantiate a TimeStampNanoTZVector.
TimeStampNanoTZVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampNanoTZVector
Instantiate a TimeStampNanoTZVector.
TimeStampNanoTZWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampNanoTZWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampNanoTZWriterImpl(TimeStampNanoTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
TimeStampNanoVector - Class in org.apache.arrow.vector
TimeStampNanoVector implements a fixed width vector (8 bytes) of timestamp (nanosecond resolution) values which could be null.
TimeStampNanoVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampNanoVector
Instantiate a TimeStampNanoVector.
TimeStampNanoVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampNanoVector
Instantiate a TimeStampNanoVector.
TimeStampNanoVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampNanoVector
Instantiate a TimeStampNanoVector.
TimeStampNanoWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampNanoWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampNanoWriterImpl(TimeStampNanoVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampSec() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampSec(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampSecHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampSecHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampSecHolder
 
TimeStampSecHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampSecHolderReaderImpl(TimeStampSecHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
 
TimeStampSecReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampSecReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampSecReaderImpl(TimeStampSecVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampSecReaderImpl
 
timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
timeStampSecTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
timeStampSecTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
timeStampSecTZ(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TimeStampSecTZHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TimeStampSecTZHolder() - Constructor for class org.apache.arrow.vector.holders.TimeStampSecTZHolder
 
TimeStampSecTZHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampSecTZHolderReaderImpl(TimeStampSecTZHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
 
TimeStampSecTZReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TimeStampSecTZReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TimeStampSecTZReaderImpl(TimeStampSecTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampSecTZReaderImpl
 
TimeStampSecTZVector - Class in org.apache.arrow.vector
TimeStampSecTZVector implements a fixed width vector (8 bytes) of timestamp (seconds resolution) values which could be null.
TimeStampSecTZVector(String, BufferAllocator, String) - Constructor for class org.apache.arrow.vector.TimeStampSecTZVector
Instantiate a TimeStampSecTZVector.
TimeStampSecTZVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampSecTZVector
Instantiate a TimeStampSecTZVector.
TimeStampSecTZVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampSecTZVector
Instantiate a TimeStampSecTZVector.
TimeStampSecTZWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampSecTZWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampSecTZWriterImpl(TimeStampSecTZVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
TimeStampSecVector - Class in org.apache.arrow.vector
TimeStampSecVector implements a fixed width vector (8 bytes) of timestamp (seconds resolution) values which could be null.
TimeStampSecVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampSecVector
Instantiate a TimeStampSecVector.
TimeStampSecVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampSecVector
Instantiate a TimeStampSecVector.
TimeStampSecVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampSecVector
Instantiate a TimeStampSecVector.
TimeStampSecWriter - Interface in org.apache.arrow.vector.complex.writer
 
TimeStampSecWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TimeStampSecWriterImpl(TimeStampSecVector) - Constructor for class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
TimestampTZConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume timestamp (with time zone) type values from ResultSet.
TimestampTZConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.TimestampTZConsumer
 
TimeStampVector - Class in org.apache.arrow.vector
TimeStampVector is an abstract interface for fixed width vector (8 bytes) of timestamp values which could be null.
TimeStampVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampVector
Instantiate a TimeStampVector.
TimeStampVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TimeStampVector
Instantiate a TimeStampVector.
TimeStampVector.TransferImpl - Class in org.apache.arrow.vector
TimeUnit - Class in org.apache.arrow.flatbuf
 
TimeUnit - Enum in org.apache.arrow.vector.types
Resolutions that times can be stored with.
timezone() - Method in class org.apache.arrow.flatbuf.Timestamp
The timezone is an optional string indicating the name of a timezone, one of: * As used in the Olson timezone database (the "tz database" or "tzdata"), such as "America/New_York".
timezone - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMicroTZHolder
 
timezone - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMilliTZHolder
 
timezone - Variable in class org.apache.arrow.vector.holders.NullableTimeStampNanoTZHolder
 
timezone - Variable in class org.apache.arrow.vector.holders.NullableTimeStampSecTZHolder
 
timezone - Variable in class org.apache.arrow.vector.holders.TimeStampMicroTZHolder
 
timezone - Variable in class org.apache.arrow.vector.holders.TimeStampMilliTZHolder
 
timezone - Variable in class org.apache.arrow.vector.holders.TimeStampNanoTZHolder
 
timezone - Variable in class org.apache.arrow.vector.holders.TimeStampSecTZHolder
 
timezoneAsByteBuffer() - Method in class org.apache.arrow.flatbuf.Timestamp
 
timezoneInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.Timestamp
 
tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
tinyInt() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
tinyInt() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
tinyInt(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
TinyIntBinder - Class in org.apache.arrow.adapter.jdbc.binder
A column binder for 8-bit integers.
TinyIntBinder(TinyIntVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.TinyIntBinder
 
TinyIntBinder(TinyIntVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.TinyIntBinder
 
TinyIntConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume tinyInt type values from ResultSet.
TinyIntConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.TinyIntConsumer
 
TinyIntHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
TinyIntHolder() - Constructor for class org.apache.arrow.vector.holders.TinyIntHolder
 
TinyIntHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
TinyIntHolderReaderImpl(TinyIntHolder) - Constructor for class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
 
TinyIntReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
TinyIntReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
TinyIntReaderImpl(TinyIntVector) - Constructor for class org.apache.arrow.vector.complex.impl.TinyIntReaderImpl
 
TinyIntVector - Class in org.apache.arrow.vector
TinyIntVector implements a fixed width (1 bytes) vector of byte values which could be null.
TinyIntVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.TinyIntVector
Instantiate a TinyIntVector.
TinyIntVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.TinyIntVector
Instantiate a TinyIntVector.
TinyIntVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.TinyIntVector
Instantiate a TinyIntVector.
TinyIntWriter - Interface in org.apache.arrow.vector.complex.writer
 
TinyIntWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
TinyIntWriterImpl(TinyIntVector) - Constructor for class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.Action
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.Location
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.Result
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
toBuilder() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
toBuilder() - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
toByteArray() - Method in class org.apache.arrow.vector.types.pojo.Schema
Deprecated.
This method does not encapsulate the schema in a Message payload which is incompatible with other languages. Use Schema.serializeAsMessage() instead.
toCallOption() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Gets the CallOptions from this ConnectionConfig.
toDeltaVector(BaseIntVector, BaseIntVector) - Static method in class org.apache.arrow.algorithm.misc.PartialSumUtils
Converts an input vector to the delta vector.
toDuration(long, TimeUnit) - Static method in class org.apache.arrow.vector.DurationVector
Converts the given value and unit to the appropriate Duration.
toFlatbufID() - Method in enum org.apache.arrow.vector.types.MetadataVersion
 
toGrpcException(Throwable) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert arbitrary exceptions to a StatusRuntimeException or StatusException.
toGrpcStatus(CallStatus) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert from a Flight status to a gRPC status.
toGrpcStatusCode(FlightStatusCode) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Convert from a Flight status code to a gRPC status code.
toHexString(long, int) - Method in class org.apache.arrow.memory.ArrowBuf
Return the buffer's byte contents in the form of a hex dump.
toImmutableList(Iterable<T>) - Static method in class org.apache.arrow.util.Collections2
Converts the iterable into a new immutable List.
toJson() - Method in class org.apache.arrow.vector.types.pojo.Schema
Returns the JSON string representation of this schema.
TOKEN_KEY - Static variable in class org.apache.arrow.flight.auth.AuthConstants
 
TOKEN_NAME - Static variable in class org.apache.arrow.flight.auth.AuthConstants
 
toList(Iterator<T>) - Static method in class org.apache.arrow.util.Collections2
Creates a List from the elements remaining in iterator.
toList(Iterable<T>) - Static method in class org.apache.arrow.util.Collections2
Converts the iterable into a new List.
toMemoryFormat(Field, BufferAllocator, Map<Long, Dictionary>) - Static method in class org.apache.arrow.vector.util.DictionaryUtility
Convert field and child fields that have a dictionary encoding to memory format, so fields have the index type.
toMessageFormat(Field, DictionaryProvider, Set<Long>) - Static method in class org.apache.arrow.vector.util.DictionaryUtility
Convert field and child fields that have a dictionary encoding to message format, so fields have the dictionary type.
toPartialSumVector(BaseIntVector, BaseIntVector, long) - Static method in class org.apache.arrow.algorithm.misc.PartialSumUtils
Converts an input vector to a partial sum vector.
toRuntimeException() - Method in class org.apache.arrow.flight.CallStatus
Convert the status to an equivalent exception.
toSocketAddress() - Method in class org.apache.arrow.flight.Location
Helper method to turn this Location into a SocketAddress.
toStatus() - Method in enum org.apache.arrow.flight.FlightStatusCode
Create a blank CallStatus with this code.
toString() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcArray
 
toString() - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcTime
 
toString() - Method in class org.apache.arrow.flight.ActionType
 
toString() - Method in class org.apache.arrow.flight.CallStatus
 
toString() - Method in class org.apache.arrow.flight.CancelFlightInfoResult
 
toString() - Method in class org.apache.arrow.flight.FlightCallHeaders
 
toString() - Method in class org.apache.arrow.flight.FlightDescriptor
 
toString() - Method in class org.apache.arrow.flight.FlightEndpoint
 
toString() - Method in class org.apache.arrow.flight.FlightInfo
 
toString() - Method in exception org.apache.arrow.flight.FlightRuntimeException
 
toString() - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
 
toString() - Method in class org.apache.arrow.flight.Location
 
toString() - Method in class org.apache.arrow.flight.PollInfo
 
toString() - Method in class org.apache.arrow.flight.sql.FlightSqlClient.SubstraitPlan
 
toString() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
 
toString() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails
 
toString() - Method in class org.apache.arrow.memory.ArrowBuf
 
toString() - Method in class org.apache.arrow.memory.util.StackTrace
 
toString(Iterator<?>) - Static method in class org.apache.arrow.util.Collections2
Creates a human readable string from the remaining elements in iterator.
toString() - Method in class org.apache.arrow.vector.BaseValueVector
Representation of vector suitable for debugging.
toString() - Method in class org.apache.arrow.vector.BufferLayout
 
toString() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
 
toString() - Method in class org.apache.arrow.vector.complex.UnionVector
 
toString() - Method in class org.apache.arrow.vector.dictionary.Dictionary
 
toString() - Method in class org.apache.arrow.vector.holders.BigIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.BitHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.DateDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.DateMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.Decimal256Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.DecimalHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.DurationHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.Float4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.Float8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.IntervalDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.IntervalYearHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.IntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.LargeVarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.LargeVarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableBigIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableBitHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableDateDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableDateMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableDecimal256Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableDecimalHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableDurationHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableFloat4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableFloat8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableIntervalDayHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableIntervalYearHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableSmallIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMicroTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampMilliTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampNanoTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTimeStampSecTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableTinyIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableUInt1Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableUInt2Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableUInt4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableUInt8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableVarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.NullableVarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.SmallIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampMicroHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampMicroTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampMilliHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampMilliTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampNanoHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampNanoTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampSecHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TimeStampSecTZHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.TinyIntHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.UInt1Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.UInt2Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.UInt4Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.UInt8Holder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.VarBinaryHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.holders.VarCharHolder
Reason for not supporting the operation is that ValueHolders are potential scalar replacements and hence we don't want any methods to be invoked on them.
toString() - Method in class org.apache.arrow.vector.ipc.message.ArrowBodyCompression
 
toString() - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
 
toString() - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
toString() - Method in class org.apache.arrow.vector.ipc.message.ArrowFieldNode
 
toString() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
toString() - Method in class org.apache.arrow.vector.PeriodDuration
 
toString() - Method in class org.apache.arrow.vector.TypeLayout
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
toString() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
toString() - Method in class org.apache.arrow.vector.types.pojo.DictionaryEncoding
 
toString() - Method in class org.apache.arrow.vector.types.pojo.Field
 
toString() - Method in class org.apache.arrow.vector.types.pojo.Schema
 
toString() - Method in class org.apache.arrow.vector.UInt1Vector
 
toString() - Method in class org.apache.arrow.vector.UInt2Vector
 
toString() - Method in class org.apache.arrow.vector.UInt4Vector
 
toString() - Method in class org.apache.arrow.vector.UInt8Vector
 
toString() - Method in class org.apache.arrow.vector.util.JsonStringArrayList
 
toString() - Method in class org.apache.arrow.vector.util.JsonStringHashMap
 
toString() - Method in class org.apache.arrow.vector.util.ReusableByteArray
 
toString() - Method in class org.apache.arrow.vector.util.Text
 
TOTAL_BYTES_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
TOTAL_RECORDS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
touch() - Method in class io.netty.buffer.NettyArrowBuf
 
touch(Object) - Method in class io.netty.buffer.NettyArrowBuf
 
toVectorSchemaRoot() - Method in class org.apache.arrow.vector.table.BaseTable
Returns a new VectorSchemaRoot with the data and schema from this table.
toVerboseString() - Method in interface org.apache.arrow.memory.BufferAllocator
Return a verbose string describing this allocator.
Transaction(byte[]) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.Transaction
 
TRANSACTION_ID - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
transfer() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector.StructTransferPair
 
transfer() - Method in class org.apache.arrow.vector.complex.StructVector.NullableStructTransferPair
 
transfer() - Method in class org.apache.arrow.vector.TimeStampVector.TransferImpl
 
transfer() - Method in interface org.apache.arrow.vector.util.TransferPair
 
transferBuffer(ArrowBuf, BufferAllocator) - Static method in class org.apache.arrow.vector.BaseValueVector
 
TransferImpl(TimeStampVector) - Constructor for class org.apache.arrow.vector.TimeStampVector.TransferImpl
 
transferOwnership(ArrowBuf, BufferAllocator) - Method in class org.apache.arrow.memory.BufferLedger
Transfer the memory accounting ownership of this ArrowBuf to another allocator.
transferOwnership(ArrowBuf, BufferAllocator) - Method in interface org.apache.arrow.memory.ReferenceManager
Duplicate the memory accounting ownership of the backing allocation of the given ArrowBuf in another allocator.
TransferPair - Interface in org.apache.arrow.vector.util
Interface for copying values between a pair of two vectors of the same type.
transferTo(BaseFixedWidthVector) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Transfer this vector's data to another vector.
transferTo(BaseLargeVariableWidthVector) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Transfer this vector's data to another vector.
transferTo(BaseVariableWidthVector) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Transfer this vector'data to another vector.
transform(VectorSchemaRoot, VectorSchemaRoot) - Method in interface org.apache.arrow.driver.jdbc.utils.VectorSchemaRootTransformer
 
transportHint(String, Object) - Method in class org.apache.arrow.flight.FlightServer.Builder
Provide a transport-specific option.
truncate(long) - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
trustedCertificates(InputStream) - Method in class org.apache.arrow.flight.FlightClient.Builder
Set the trusted TLS certificates.
type() - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
 
type(Table) - Method in class org.apache.arrow.flatbuf.Field
This is the type of the decoded value if the field is dictionary encoded.
type(Table) - Method in class org.apache.arrow.flatbuf.SparseTensor
The type of data contained in a value cell.
type(Table) - Method in class org.apache.arrow.flatbuf.Tensor
The type of data contained in a value cell.
Type - Class in org.apache.arrow.flatbuf
---------------------------------------------------------------------- Top-level Type value, enabling extensible type-specific metadata.
TYPE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.Action
 
TYPE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.ActionType
 
TYPE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Bool
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Date
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Duration
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Int
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Interval
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.List
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Map
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Null
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Struct
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Time
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
TYPE_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.BigIntVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.complex.DenseUnionVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.complex.UnionVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.DateDayVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.DateMilliVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.Decimal256Vector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.DecimalVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.DurationVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.Float4Vector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.Float8Vector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.IntervalDayVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.IntervalMonthDayNanoVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.IntervalYearVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.IntVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.SmallIntVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.TimeMicroVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.TimeMilliVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.TimeNanoVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.TimeSecVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.TimeStampVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.TinyIntVector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.UInt1Vector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.UInt2Vector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.UInt4Vector
 
TYPE_WIDTH - Static variable in class org.apache.arrow.vector.UInt8Vector
 
typeBuffer() - Static method in class org.apache.arrow.vector.BufferLayout
 
typeBuffer - Variable in class org.apache.arrow.vector.complex.UnionVector
 
TypeEqualsVisitor - Class in org.apache.arrow.vector.compare
Visitor to compare type equals for vectors.
TypeEqualsVisitor(ValueVector) - Constructor for class org.apache.arrow.vector.compare.TypeEqualsVisitor
Construct an instance.
TypeEqualsVisitor(ValueVector, boolean, boolean) - Constructor for class org.apache.arrow.vector.compare.TypeEqualsVisitor
Construct an instance.
typeId - Variable in class org.apache.arrow.vector.holders.DenseUnionHolder
 
typeIds(int) - Method in class org.apache.arrow.flatbuf.Union
 
typeIdsAsByteBuffer() - Method in class org.apache.arrow.flatbuf.Union
 
typeIdsInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.Union
 
typeIdsLength() - Method in class org.apache.arrow.flatbuf.Union
 
typeIdsVector() - Method in class org.apache.arrow.flatbuf.Union
 
typeIdsVector(IntVector) - Method in class org.apache.arrow.flatbuf.Union
 
typeify(ValueVector, Class<T>) - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
 
TypeLayout - Class in org.apache.arrow.vector
The buffer layout of vectors for a given type.
TypeLayout(List<BufferLayout>) - Constructor for class org.apache.arrow.vector.TypeLayout
 
TypeLayout(BufferLayout...) - Constructor for class org.apache.arrow.vector.TypeLayout
 
typeName(String) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
Sets the type name.
Types - Class in org.apache.arrow.vector.types
An enumeration of all logical types supported by this library.
Types() - Constructor for class org.apache.arrow.vector.types.Types
 
Types.MinorType - Enum in org.apache.arrow.vector.types
The actual enumeration of types.
typeType() - Method in class org.apache.arrow.flatbuf.Field
 
typeType() - Method in class org.apache.arrow.flatbuf.SparseTensor
 
typeType() - Method in class org.apache.arrow.flatbuf.Tensor
 

U

uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt1() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt1() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
uInt1(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
UInt1Comparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt1Comparator
 
UInt1Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
UInt1Holder() - Constructor for class org.apache.arrow.vector.holders.UInt1Holder
 
UInt1HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt1HolderReaderImpl(UInt1Holder) - Constructor for class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
 
UInt1Reader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
UInt1ReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
UInt1ReaderImpl(UInt1Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt1ReaderImpl
 
UInt1Vector - Class in org.apache.arrow.vector
UInt1Vector implements a fixed width (1 bytes) vector of integer values which could be null.
UInt1Vector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt1Vector
 
UInt1Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt1Vector
 
UInt1Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt1Vector
Constructor for UInt1Vector.
UInt1Writer - Interface in org.apache.arrow.vector.complex.writer
 
UInt1WriterImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt1WriterImpl(UInt1Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt2() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt2() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
uInt2(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
UInt2Comparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt2Comparator
 
UInt2Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
UInt2Holder() - Constructor for class org.apache.arrow.vector.holders.UInt2Holder
 
UInt2HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt2HolderReaderImpl(UInt2Holder) - Constructor for class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
 
UInt2Reader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
UInt2ReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
UInt2ReaderImpl(UInt2Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt2ReaderImpl
 
UInt2Vector - Class in org.apache.arrow.vector
UInt2Vector implements a fixed width (2 bytes) vector of integer values which could be null.
UInt2Vector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt2Vector
 
UInt2Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt2Vector
 
UInt2Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt2Vector
Constructor for UInt2Vector type.
UInt2Writer - Interface in org.apache.arrow.vector.complex.writer
 
UInt2WriterImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt2WriterImpl(UInt2Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt4() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt4() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
uInt4(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
UInt4Comparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt4Comparator
 
UInt4Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
UInt4Holder() - Constructor for class org.apache.arrow.vector.holders.UInt4Holder
 
UInt4HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt4HolderReaderImpl(UInt4Holder) - Constructor for class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
 
UInt4Reader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
UInt4ReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
UInt4ReaderImpl(UInt4Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt4ReaderImpl
 
UInt4Vector - Class in org.apache.arrow.vector
UInt4Vector implements a fixed width (4 bytes) vector of integer values which could be null.
UInt4Vector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt4Vector
 
UInt4Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt4Vector
 
UInt4Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt4Vector
Constructor for UInt4Vector.
UInt4Writer - Interface in org.apache.arrow.vector.complex.writer
 
UInt4WriterImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt4WriterImpl(UInt4Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt8() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
uInt8() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
uInt8(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
UInt8Comparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.UInt8Comparator
 
UInt8Holder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
UInt8Holder() - Constructor for class org.apache.arrow.vector.holders.UInt8Holder
 
UInt8HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt8HolderReaderImpl(UInt8Holder) - Constructor for class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
 
UInt8Reader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
UInt8ReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
UInt8ReaderImpl(UInt8Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt8ReaderImpl
 
UInt8Vector - Class in org.apache.arrow.vector
UInt8Vector implements a fixed width vector (8 bytes) of integer values which could be null.
UInt8Vector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt8Vector
 
UInt8Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt8Vector
 
UInt8Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.UInt8Vector
Constructor for UInt8Vector.
UInt8Writer - Interface in org.apache.arrow.vector.complex.writer
 
UInt8WriterImpl - Class in org.apache.arrow.vector.complex.impl
 
UInt8WriterImpl(UInt8Vector) - Constructor for class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
UNAUTHENTICATED - Static variable in class org.apache.arrow.flight.CallStatus
 
UNAUTHORIZED - Static variable in class org.apache.arrow.flight.CallStatus
 
UNAVAILABLE - Static variable in class org.apache.arrow.flight.CallStatus
 
UNIMPLEMENTED - Static variable in class org.apache.arrow.flight.CallStatus
 
Union - Static variable in class org.apache.arrow.flatbuf.Type
 
Union - Class in org.apache.arrow.flatbuf
A union is a complex type with children in Field By default ids in the type vector refer to the offsets in the children optionally typeIds provides an indirection between the child offset and the type id for each child `typeIds[offset]` is the id used in the type vector
Union() - Constructor for class org.apache.arrow.flatbuf.Union
 
Union(UnionMode, int[]) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Union
 
Union.Vector - Class in org.apache.arrow.flatbuf
 
UnionAvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Union Arrow types.
UnionAvaticaParameterConverter(ArrowType.Union) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.UnionAvaticaParameterConverter
 
UnionFixedSizeListReader - Class in org.apache.arrow.vector.complex.impl
Reader for fixed size list vectors.
UnionFixedSizeListReader(FixedSizeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
Constructs a new instance that reads data in vector.
UnionFixedSizeListWriter - Class in org.apache.arrow.vector.complex.impl
 
UnionFixedSizeListWriter(FixedSizeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
UnionFixedSizeListWriter(FixedSizeListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
UnionFixedSizeListWriter(FixedSizeListVector, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
UnionHolder - Class in org.apache.arrow.vector.holders
ValueHolder for Union Vectors.
UnionHolder() - Constructor for class org.apache.arrow.vector.holders.UnionHolder
 
UnionLargeListReader - Class in org.apache.arrow.vector.complex.impl
FieldReader for list of union types.
UnionLargeListReader(LargeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListReader
 
UnionLargeListWriter - Class in org.apache.arrow.vector.complex.impl
 
UnionLargeListWriter(LargeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
UnionLargeListWriter(LargeListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
UnionLargeListWriter(LargeListVector, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
UnionListReader - Class in org.apache.arrow.vector.complex.impl
FieldReader for list of union types.
UnionListReader(ListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListReader
 
UnionListWriter - Class in org.apache.arrow.vector.complex.impl
 
UnionListWriter(ListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListWriter
 
UnionListWriter(ListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListWriter
 
UnionListWriter(ListVector, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListWriter
 
UnionMapReader - Class in org.apache.arrow.vector.complex.impl
Reader for a MapVector.
UnionMapReader(MapVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionMapReader
Construct a new reader for the given vector.
UnionMapWriter - Class in org.apache.arrow.vector.complex.impl
Writer for MapVectors.
UnionMapWriter(MapVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
UnionMode - Class in org.apache.arrow.flatbuf
 
UnionMode - Enum in org.apache.arrow.vector.types
Different memory layouts for Union Vectors.
UnionReader - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template UnionReader.java
UnionReader(UnionVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionReader
 
UnionVector - Class in org.apache.arrow.vector.complex
 
UnionVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.UnionVector
 
UnionWriter - Class in org.apache.arrow.vector.complex.impl
 
UnionWriter(UnionVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionWriter
 
UnionWriter(UnionVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.UnionWriter
 
unit() - Method in class org.apache.arrow.flatbuf.Date
 
unit() - Method in class org.apache.arrow.flatbuf.Duration
 
unit() - Method in class org.apache.arrow.flatbuf.Interval
 
unit() - Method in class org.apache.arrow.flatbuf.Time
 
unit() - Method in class org.apache.arrow.flatbuf.Timestamp
 
unit - Variable in class org.apache.arrow.vector.holders.DurationHolder
 
unit - Variable in class org.apache.arrow.vector.holders.NullableDurationHolder
 
UNKNOWN - Static variable in class org.apache.arrow.flight.CallStatus
 
UNKNOWN_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
Protobuf pattern, not used.
unLoad() - Method in interface org.apache.arrow.vector.BufferBacked
 
unpackAndParseOrThrow(byte[], Class<T>) - Static method in class org.apache.arrow.flight.sql.FlightSqlUtils
Helper to parse and unpack Any objects to the specific protobuf object.
unpackOrThrow(Any, Class<T>) - Static method in class org.apache.arrow.flight.sql.FlightSqlUtils
Helper to unpack Any objects to the specific protobuf object.
unregister(ArrowType.ExtensionType) - Static method in class org.apache.arrow.vector.types.pojo.ExtensionTypeRegistry
 
UNSAFE - Static variable in class org.apache.arrow.memory.util.MemoryUtil
The unsafe object from which to access the off-heap memory.
UnsafeAllocationManager - Class in org.apache.arrow.memory
Allocation manager based on unsafe API.
UnsafeDirectLittleEndian - Class in io.netty.buffer
The underlying class we use for little-endian access to memory.
unsetBit(ArrowBuf, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
Set the bit at provided index to 0.
unsignedIntCompare(int, int) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
 
unsignedLongCompare(long, long) - Static method in class org.apache.arrow.memory.util.ByteFunctionHelpers
Compares the two specified long values, treating them as unsigned values between 0 and 2^64 - 1 inclusive.
UNUSED - Static variable in class org.apache.arrow.flatbuf.Feature
Needed to make flatbuffers happy.
unwrap() - Method in class io.netty.buffer.NettyArrowBuf
 
unwrap(Class<T>) - Method in class org.apache.arrow.driver.jdbc.ArrowFlightJdbcDataSource
 
unwrap(Class<T>) - Method in class org.apache.arrow.driver.jdbc.utils.ConnectionWrapper
 
unwrap() - Method in class org.apache.arrow.memory.ArrowByteBufAllocator
Deprecated.
 
unwrapBuffer(ArrowBuf) - Static method in class io.netty.buffer.NettyArrowBuf
unwrap arrow buffer into a netty buffer.
UPDATE_PREPARED_STATEMENT_EXPECTED_ROWS - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
UPDATE_PREPARED_STATEMENT_WITH_TRANSACTION_EXPECTED_ROWS - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
UPDATE_STATEMENT_EXPECTED_ROWS - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
UPDATE_STATEMENT_WITH_TRANSACTION_EXPECTED_ROWS - Static variable in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
URI_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.Location
 
UrlParser - Class in org.apache.arrow.driver.jdbc.utils
URL Parser for extracting key values from a connection string.
useEncryption() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Whether to use TLS encryption.
useMTlsClientVerification(File) - Method in class org.apache.arrow.flight.FlightServer.Builder
Enable Client Verification via mTLS on the server.
useMTlsClientVerification(InputStream) - Method in class org.apache.arrow.flight.FlightServer.Builder
Enable mTLS on the server.
USERNAME_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
useSystemTrustStore() - Method in class org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl
Check if the JDBC should use the trusted store files from the operating system.
useTls() - Method in class org.apache.arrow.flight.FlightClient.Builder
Force the client to connect over TLS.
useTls(File, File) - Method in class org.apache.arrow.flight.FlightServer.Builder
Enable TLS on the server.
useTls(InputStream, InputStream) - Method in class org.apache.arrow.flight.FlightServer.Builder
Enable TLS on the server.
Utf8 - Static variable in class org.apache.arrow.flatbuf.Type
 
Utf8 - Class in org.apache.arrow.flatbuf
Unicode with UTF-8 encoding
Utf8() - Constructor for class org.apache.arrow.flatbuf.Utf8
 
Utf8() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Utf8
 
Utf8.Vector - Class in org.apache.arrow.flatbuf
 
Utf8AvaticaParameterConverter - Class in org.apache.arrow.driver.jdbc.converter.impl
AvaticaParameterConverter for Utf8 Arrow types.
Utf8AvaticaParameterConverter(ArrowType.Utf8) - Constructor for class org.apache.arrow.driver.jdbc.converter.impl.Utf8AvaticaParameterConverter
 
utf8Length(String) - Static method in class org.apache.arrow.vector.util.Text
For the given string, returns the number of UTF-8 bytes required to encode the string.
Utf8View - Static variable in class org.apache.arrow.flatbuf.Type
 
Utf8View - Class in org.apache.arrow.flatbuf
Logically the same as Utf8, but the internal representation uses a view struct that contains the string length and either the string's entire data inline (for small strings) or an inlined prefix, an index of another buffer, and an offset pointing to a slice in that buffer (for non-small strings).
Utf8View() - Constructor for class org.apache.arrow.flatbuf.Utf8View
 
Utf8View.Vector - Class in org.apache.arrow.flatbuf
 

V

V1 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
0.1.0 (October 2016).
V2 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
0.2.0 (February 2017).
V3 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
0.3.0 -> 0.7.1 (May - December 2017).
V4 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
>= 0.8.0 (December 2017).
V5 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
>= 1.0.0 (July 2020).
validate(String, String) - Method in interface org.apache.arrow.flight.auth2.BasicCallHeaderAuthenticator.CredentialValidator
Validate the supplied credentials (username/password) and return the peer identity.
validate(Schema, FlightInfo, FlightSqlClient) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
validate(ValueVector) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
Validate the passed left vector, if it is changed, reset and check type.
validate(ValueVector) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Utility to validate vector in O(1) time.
validate(VectorSchemaRoot) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Utility to validate vector schema root in O(1) time.
validate() - Method in interface org.apache.arrow.vector.ValueVector
 
validateBearer(String) - Method in class org.apache.arrow.flight.auth2.BearerTokenAuthenticator
Validate the bearer token.
validateBearer(String) - Method in class org.apache.arrow.flight.auth2.GeneratedBearerTokenAuthenticator
 
ValidateException(String) - Constructor for exception org.apache.arrow.vector.validate.ValidateUtil.ValidateException
 
validateFull(ValueVector) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Utility to validate vector in O(n) time, where n is the value count.
validateFull(VectorSchemaRoot) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
Utility to validate vector in O(n) time, where n is the value count.
validateFull() - Method in interface org.apache.arrow.vector.ValueVector
 
validateOrThrow(boolean, String) - Static method in class org.apache.arrow.vector.validate.ValidateUtil
Validate the expression.
validateOrThrow(boolean, String, Object...) - Static method in class org.apache.arrow.vector.validate.ValidateUtil
Validate the expression.
validateScalars() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
Validate the scalar values held by this vector.
validateScalars() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
Validate the scalar values held by this vector.
validateScalars() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
Validate the scalar values held by this vector.
validateScalars() - Method in class org.apache.arrow.vector.Decimal256Vector
 
validateScalars() - Method in class org.apache.arrow.vector.DecimalVector
 
validateScalars() - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
 
validateScalars() - Method in class org.apache.arrow.vector.LargeVarCharVector
 
validateScalars() - Method in class org.apache.arrow.vector.VarCharVector
 
validateSchema(Schema, SchemaResult) - Method in class org.apache.arrow.flight.integration.tests.FlightSqlScenario
 
validateUTF8(byte[]) - Static method in class org.apache.arrow.vector.util.Text
Check if a byte array contains valid utf-8.
validateUTF8(byte[], int, int) - Static method in class org.apache.arrow.vector.util.Text
Check to see if a byte array is valid utf-8.
validateUTF8NoThrow(byte[]) - Static method in class org.apache.arrow.vector.util.Text
Check if a byte array contains valid utf-8.
ValidateUtil - Class in org.apache.arrow.vector.validate
Utilities for vector validation.
ValidateUtil.ValidateException - Exception in org.apache.arrow.vector.validate
A exception that is thrown when the vector validation fails.
ValidateVectorBufferVisitor - Class in org.apache.arrow.vector.validate
Visitor to validate vector buffers.
ValidateVectorBufferVisitor() - Constructor for class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
ValidateVectorDataVisitor - Class in org.apache.arrow.vector.validate
Utility for validating vector data.
ValidateVectorDataVisitor() - Constructor for class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
ValidateVectorTypeVisitor - Class in org.apache.arrow.vector.validate
Utility to validate vector type information.
ValidateVectorTypeVisitor() - Constructor for class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
ValidateVectorVisitor - Class in org.apache.arrow.vector.validate
Visitor to validate vector (without validating data).
ValidateVectorVisitor() - Constructor for class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Binary
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.BinaryView
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.BodyCompression
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Bool
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Date
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Decimal
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.DictionaryBatch
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Duration
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Field
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.FixedSizeList
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.FloatingPoint
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Footer
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Int
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Interval
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.KeyValue
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.LargeBinary
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.LargeList
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.LargeListView
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.LargeUtf8
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.List
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.ListView
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Map
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Message
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Null
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.RecordBatch
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.RunEndEncoded
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Schema
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.SparseTensor
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Struct_
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Tensor
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.TensorDim
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Time
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Timestamp
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Union
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Utf8
 
ValidateVersion() - Static method in class org.apache.arrow.flatbuf.Utf8View
 
Validator - Class in org.apache.arrow.vector.util
Utility class for validating arrow data structures.
Validator() - Constructor for class org.apache.arrow.vector.util.Validator
 
validityAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.ListVector
 
validityBuffer - Variable in class org.apache.arrow.vector.BaseFixedWidthVector
 
validityBuffer - Variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
validityBuffer - Variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
validityBuffer - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
validityBuffer - Variable in class org.apache.arrow.vector.complex.ListVector
 
validityBuffer - Variable in class org.apache.arrow.vector.complex.StructVector
 
validityVector() - Static method in class org.apache.arrow.vector.BufferLayout
 
value() - Method in class org.apache.arrow.flatbuf.KeyValue
 
value() - Method in class org.apache.arrow.vector.complex.impl.UnionMapReader
Start reading a value element from the map entry.
value() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
Return the value writer that is used to write to the "value" field.
value() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
value() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.MapWriter
 
value - Variable in class org.apache.arrow.vector.holders.BigIntHolder
 
value - Variable in class org.apache.arrow.vector.holders.BitHolder
 
value - Variable in class org.apache.arrow.vector.holders.DateDayHolder
 
value - Variable in class org.apache.arrow.vector.holders.DateMilliHolder
 
value - Variable in class org.apache.arrow.vector.holders.DurationHolder
 
value - Variable in class org.apache.arrow.vector.holders.Float4Holder
 
value - Variable in class org.apache.arrow.vector.holders.Float8Holder
 
value - Variable in class org.apache.arrow.vector.holders.IntervalYearHolder
 
value - Variable in class org.apache.arrow.vector.holders.IntHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableBigIntHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableBitHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableDateDayHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableDateMilliHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableDurationHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableFloat4Holder
 
value - Variable in class org.apache.arrow.vector.holders.NullableFloat8Holder
 
value - Variable in class org.apache.arrow.vector.holders.NullableIntervalYearHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableIntHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableSmallIntHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeMicroHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeMilliHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeNanoHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeSecHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMicroHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMicroTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMilliHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampMilliTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampNanoHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampNanoTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampSecHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTimeStampSecTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableTinyIntHolder
 
value - Variable in class org.apache.arrow.vector.holders.NullableUInt1Holder
 
value - Variable in class org.apache.arrow.vector.holders.NullableUInt2Holder
 
value - Variable in class org.apache.arrow.vector.holders.NullableUInt4Holder
 
value - Variable in class org.apache.arrow.vector.holders.NullableUInt8Holder
 
value - Variable in class org.apache.arrow.vector.holders.SmallIntHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeMicroHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeMilliHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeNanoHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeSecHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampMicroHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampMicroTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampMilliHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampMilliTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampNanoHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampNanoTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampSecHolder
 
value - Variable in class org.apache.arrow.vector.holders.TimeStampSecTZHolder
 
value - Variable in class org.apache.arrow.vector.holders.TinyIntHolder
 
value - Variable in class org.apache.arrow.vector.holders.UInt1Holder
 
value - Variable in class org.apache.arrow.vector.holders.UInt2Holder
 
value - Variable in class org.apache.arrow.vector.holders.UInt4Holder
 
value - Variable in class org.apache.arrow.vector.holders.UInt8Holder
 
VALUE_NAME - Static variable in class org.apache.arrow.vector.complex.MapVector
 
valueAsByteBuffer() - Method in class org.apache.arrow.flatbuf.KeyValue
 
valueBuffer - Variable in class org.apache.arrow.vector.BaseFixedWidthVector
 
valueBuffer - Variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
valueBuffer - Variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
valueClass() - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
 
valueCount - Variable in class org.apache.arrow.vector.BaseFixedWidthVector
 
valueCount - Variable in class org.apache.arrow.vector.BaseLargeVariableWidthVector
 
valueCount - Variable in class org.apache.arrow.vector.BaseVariableWidthVector
 
valueCount - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
valueCount - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
valueCount - Variable in class org.apache.arrow.vector.complex.NonNullableStructVector
 
ValueEpsilonEqualizers - Class in org.apache.arrow.vector.compare.util
Vector value equalizers that regard values as equal if their difference is within a small threshold (epsilon).
ValueEpsilonEqualizers.Float4EpsilonEqualizer - Class in org.apache.arrow.vector.compare.util
Difference function for float values.
ValueEpsilonEqualizers.Float8EpsilonEqualizer - Class in org.apache.arrow.vector.compare.util
Difference function for double values.
ValueEpsilonEqualizers.FloatingPointEpsilonEqualizer - Class in org.apache.arrow.vector.compare.util
Difference function for floating point values.
ValueHolder - Interface in org.apache.arrow.vector.holders
Wrapper object for an individual value in Arrow.
valueInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.KeyValue
 
valueOf(String) - Static method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.flight.BackpressureStrategy.WaitResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.flight.CancelStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.flight.FlightMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.flight.FlightStatusCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
 
valueOf(String) - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.CancelResult
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
 
valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
 
valueOf(String) - Static method in enum org.apache.arrow.memory.AllocationOutcome.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.memory.DefaultAllocationManagerOption.AllocationManagerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.BufferLayout.BufferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.complex.AbstractStructVector.ConflictPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.compression.CompressionUtil.CodecType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.DateUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.FloatingPointPrecision
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.IntervalUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.MetadataVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.TimeUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.Types.MinorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.arrow.vector.types.UnionMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.BackpressureStrategy.WaitResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.CancelStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.FlightMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.FlightStatusCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.CancelResult
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.memory.AllocationOutcome.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.memory.DefaultAllocationManagerOption.AllocationManagerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.BufferLayout.BufferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.complex.AbstractStructVector.ConflictPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.compression.CompressionUtil.CodecType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.DateUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.FloatingPointPrecision
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.IntervalUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.MetadataVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.TimeUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.Types.MinorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.arrow.vector.types.UnionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.arrow.vector.util.MapWithOrdinal
 
values() - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
 
values() - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
 
values() - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
 
valuesEqual(Float4Vector, int, Float4Vector, int) - Method in class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.Float4EpsilonEqualizer
 
valuesEqual(Float8Vector, int, Float8Vector, int) - Method in class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.Float8EpsilonEqualizer
 
valuesEqual(FloatingPointVector, int, FloatingPointVector, int) - Method in class org.apache.arrow.vector.compare.util.ValueEpsilonEqualizers.FloatingPointEpsilonEqualizer
 
valuesEqual(V, int, V, int) - Method in interface org.apache.arrow.vector.compare.VectorValueEqualizer
Checks if the vectors are equal at the given positions, given that the values at both positions are non-null.
ValueVector - Interface in org.apache.arrow.vector
An abstraction that is used to store a sequence of values in an individual column.
ValueVectorUtility - Class in org.apache.arrow.vector.util
Utility methods for ValueVector.
valueWidth - Variable in class org.apache.arrow.algorithm.sort.VectorValueComparator
Width of the vector value.
ValueWithKeyIncluded<K> - Interface in org.apache.arrow.memory
Helper interface to generify a value to be included in the map where key is part of the value.
varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
varBinary() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
varBinary() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
varBinary(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
VarBinaryBinder<T extends FieldVector & ElementAddressableVector> - Class in org.apache.arrow.adapter.jdbc.binder
A binder for variable-width binary types.
VarBinaryBinder(T, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.VarBinaryBinder
Create a binder for the given vector using the given JDBC type for null values.
VarBinaryHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
VarBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.VarBinaryHolder
 
VarBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
VarBinaryHolderReaderImpl(VarBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
 
VarBinaryReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
VarBinaryReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
VarBinaryReaderImpl(VarBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.VarBinaryReaderImpl
 
VarBinaryVector - Class in org.apache.arrow.vector
VarBinaryVector implements a variable width vector of binary values which could be NULL.
VarBinaryVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.VarBinaryVector
Instantiate a VarBinaryVector.
VarBinaryVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.VarBinaryVector
Instantiate a VarBinaryVector.
VarBinaryVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.VarBinaryVector
Instantiate a VarBinaryVector.
VarBinaryWriter - Interface in org.apache.arrow.vector.complex.writer
 
VarBinaryWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
VarBinaryWriterImpl(VarBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
varChar() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
 
varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
 
varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
varChar() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
 
varChar(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructOrListWriter
 
varChar(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
 
VarCharBinder<T extends FieldVector & VariableWidthVector> - Class in org.apache.arrow.adapter.jdbc.binder
A binder for variable-width string types.
VarCharBinder(T, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.VarCharBinder
Create a binder for the given vector using the given JDBC type for null values.
VarCharConsumer - Class in org.apache.arrow.adapter.jdbc.consumer
Consumer which consume varchar type values from ResultSet.
VarCharConsumer() - Constructor for class org.apache.arrow.adapter.jdbc.consumer.VarCharConsumer
 
VarCharHolder - Class in org.apache.arrow.vector.holders
Source code generated using FreeMarker template ValueHolders.java
VarCharHolder() - Constructor for class org.apache.arrow.vector.holders.VarCharHolder
 
VarCharHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
 
VarCharHolderReaderImpl(VarCharHolder) - Constructor for class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
 
VarCharReader - Interface in org.apache.arrow.vector.complex.reader
Source code generated using FreeMarker template ComplexReaders.java
VarCharReaderImpl - Class in org.apache.arrow.vector.complex.impl
Source code generated using FreeMarker template ComplexReaders.java
VarCharReaderImpl(VarCharVector) - Constructor for class org.apache.arrow.vector.complex.impl.VarCharReaderImpl
 
VarCharVector - Class in org.apache.arrow.vector
VarCharVector implements a variable width vector of VARCHAR values which could be NULL.
VarCharVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.VarCharVector
Instantiate a VarCharVector.
VarCharVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.VarCharVector
Instantiate a VarCharVector.
VarCharVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.VarCharVector
Instantiate a VarCharVector.
VarCharWriter - Interface in org.apache.arrow.vector.complex.writer
 
VarCharWriterImpl - Class in org.apache.arrow.vector.complex.impl
 
VarCharWriterImpl(VarCharVector) - Constructor for class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
VariableWidthComparator() - Constructor for class org.apache.arrow.algorithm.sort.DefaultVectorComparators.VariableWidthComparator
 
VariableWidthOutOfPlaceVectorSorter<V extends BaseVariableWidthVector> - Class in org.apache.arrow.algorithm.sort
Default sorter for variable-width vectors.
VariableWidthOutOfPlaceVectorSorter() - Constructor for class org.apache.arrow.algorithm.sort.VariableWidthOutOfPlaceVectorSorter
 
VariableWidthVector - Interface in org.apache.arrow.vector
Interface vectors that contain variable width members (e.g.
variadicBufferCounts(int) - Method in class org.apache.arrow.flatbuf.RecordBatch
Some types such as Utf8View are represented using a variable number of buffers.
variadicBufferCountsAsByteBuffer() - Method in class org.apache.arrow.flatbuf.RecordBatch
 
variadicBufferCountsInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
variadicBufferCountsLength() - Method in class org.apache.arrow.flatbuf.RecordBatch
 
variadicBufferCountsVector() - Method in class org.apache.arrow.flatbuf.RecordBatch
 
variadicBufferCountsVector(LongVector) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
vector - Variable in class org.apache.arrow.adapter.jdbc.binder.BaseColumnBinder
 
vector - Variable in class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
 
vector - Variable in class org.apache.arrow.consumers.BaseAvroConsumer
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Binary.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.BinaryView.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Block.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.BodyCompression.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Bool.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Buffer.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Date.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Decimal.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.DictionaryBatch.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.DictionaryEncoding.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Duration.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Field.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.FieldNode.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.FixedSizeBinary.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.FixedSizeList.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.FloatingPoint.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Footer.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Int.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Interval.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.KeyValue.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.LargeBinary.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.LargeList.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.LargeListView.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.LargeUtf8.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.List.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.ListView.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Map.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Message.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Null.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.RecordBatch.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.RunEndEncoded.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Schema.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.SparseMatrixIndexCSX.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.SparseTensor.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.SparseTensorIndexCOO.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.SparseTensorIndexCSF.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Struct_.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Tensor.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.TensorDim.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Time.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Timestamp.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Union.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Utf8.Vector
 
Vector() - Constructor for class org.apache.arrow.flatbuf.Utf8View.Vector
 
vector - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
 
vector - Variable in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
vector - Variable in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
vector - Variable in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
vector - Variable in class org.apache.arrow.vector.complex.LargeListVector
 
vector - Variable in class org.apache.arrow.vector.complex.VectorWithOrdinal
 
vector1 - Variable in class org.apache.arrow.algorithm.sort.VectorValueComparator
The first vector to compare.
vector2 - Variable in class org.apache.arrow.algorithm.sort.VectorValueComparator
The second vector to compare.
VectorAppender - Class in org.apache.arrow.vector.util
Utility to append two vectors together.
VectorAppender(ValueVector) - Constructor for class org.apache.arrow.vector.util.VectorAppender
Constructs a new targetVector appender, with the given targetVector.
VectorBatchAppender - Class in org.apache.arrow.vector.util
Utility to add vector values in batch.
VectorBatchAppender() - Constructor for class org.apache.arrow.vector.util.VectorBatchAppender
 
VectorDefinitionSetter - Interface in org.apache.arrow.vector
Interface for setting a specific index values as defined/valid on a vector.
vectorEquals(ValueVector, ValueVector) - Static method in class org.apache.arrow.vector.compare.VectorEqualsVisitor
Checks if two vectors are equals with default type comparator.
vectorEquals(ValueVector, ValueVector, BiFunction<ValueVector, ValueVector, Boolean>) - Static method in class org.apache.arrow.vector.compare.VectorEqualsVisitor
Checks if two vectors are equals.
VectorEqualsVisitor - Class in org.apache.arrow.vector.compare
Visitor to compare vectors equal.
VectorEqualsVisitor() - Constructor for class org.apache.arrow.vector.compare.VectorEqualsVisitor
 
VectorLoader - Class in org.apache.arrow.vector
Loads buffers into vectors.
VectorLoader(VectorSchemaRoot) - Constructor for class org.apache.arrow.vector.VectorLoader
Construct with a root to load and will create children in root based on schema.
VectorLoader(VectorSchemaRoot, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.VectorLoader
Construct with a root to load and will create children in root based on schema.
VectorRangeSearcher - Class in org.apache.arrow.algorithm.search
Search for the range of a particular element in the target vector.
VectorRangeSearcher() - Constructor for class org.apache.arrow.algorithm.search.VectorRangeSearcher
 
VectorRank<V extends ValueVector> - Class in org.apache.arrow.algorithm.rank
Utility for calculating ranks of vector elements.
VectorRank(BufferAllocator) - Constructor for class org.apache.arrow.algorithm.rank.VectorRank
Constructs a vector rank utility.
VectorRunDeduplicator<V extends ValueVector> - Class in org.apache.arrow.algorithm.deduplicate
Remove adjacent equal elements from a vector.
VectorRunDeduplicator(V, BufferAllocator) - Constructor for class org.apache.arrow.algorithm.deduplicate.VectorRunDeduplicator
Constructs a vector run deduplicator for a given vector.
VectorSchemaRoot - Class in org.apache.arrow.vector
Holder for a set of vectors to be loaded/unloaded.
VectorSchemaRoot(Iterable<FieldVector>) - Constructor for class org.apache.arrow.vector.VectorSchemaRoot
Constructs new instance containing each of the vectors.
VectorSchemaRoot(FieldVector) - Constructor for class org.apache.arrow.vector.VectorSchemaRoot
Constructs a new instance containing the children of parent but not the parent itself.
VectorSchemaRoot(List<Field>, List<FieldVector>) - Constructor for class org.apache.arrow.vector.VectorSchemaRoot
Constructs a new instance.
VectorSchemaRoot(List<Field>, List<FieldVector>, int) - Constructor for class org.apache.arrow.vector.VectorSchemaRoot
Constructs a new instance.
VectorSchemaRoot(Schema, List<FieldVector>, int) - Constructor for class org.apache.arrow.vector.VectorSchemaRoot
Constructs a new instance.
VectorSchemaRootAppender - Class in org.apache.arrow.vector.util
Utility to append VectorSchemaRoots with the same schema.
VectorSchemaRootAppender() - Constructor for class org.apache.arrow.vector.util.VectorSchemaRootAppender
 
VectorSchemaRootTransformer - Interface in org.apache.arrow.driver.jdbc.utils
Converts Arrow's VectorSchemaRoot format to one JDBC would expect.
VectorSchemaRootTransformer.Builder - Class in org.apache.arrow.driver.jdbc.utils
Transformer's helper class; builds a new VectorSchemaRoot.
VectorSearcher - Class in org.apache.arrow.algorithm.search
Search for a particular element in the vector.
VectorUnloader - Class in org.apache.arrow.vector
Helper class that handles converting a VectorSchemaRoot to a ArrowRecordBatch.
VectorUnloader(VectorSchemaRoot) - Constructor for class org.apache.arrow.vector.VectorUnloader
Constructs a new instance of the given set of vectors.
VectorUnloader(VectorSchemaRoot, boolean, boolean) - Constructor for class org.apache.arrow.vector.VectorUnloader
Constructs a new instance.
VectorUnloader(VectorSchemaRoot, boolean, CompressionCodec, boolean) - Constructor for class org.apache.arrow.vector.VectorUnloader
Constructs a new instance.
VectorValueComparator<V extends ValueVector> - Class in org.apache.arrow.algorithm.sort
Compare two values at the given indices in the vectors.
VectorValueComparator() - Constructor for class org.apache.arrow.algorithm.sort.VectorValueComparator
Constructor for variable-width vectors.
VectorValueComparator(int) - Constructor for class org.apache.arrow.algorithm.sort.VectorValueComparator
Constructor for fixed-width vectors.
VectorValueEqualizer<V extends ValueVector> - Interface in org.apache.arrow.vector.compare
A function to determine if two vectors are equal at specified positions.
VectorVisitor<OUT,IN> - Interface in org.apache.arrow.vector.compare
Generic visitor to visit a ValueVector.
VectorWithOrdinal - Class in org.apache.arrow.vector.complex
Tuple of a ValueVector and an index into a data structure containing the ValueVector.
VectorWithOrdinal(ValueVector, int) - Constructor for class org.apache.arrow.vector.complex.VectorWithOrdinal
 
verify() - Method in class org.apache.arrow.memory.RootAllocator
Verify the accounting state of the allocation system.
verifyServer(boolean) - Method in class org.apache.arrow.flight.FlightClient.Builder
 
version() - Method in class org.apache.arrow.flatbuf.Footer
 
version() - Method in class org.apache.arrow.flatbuf.Message
 
VERSION_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
VisibleForTesting - Annotation Type in org.apache.arrow.util
Annotation to indicate a class member or class is visible only for the purposes of testing and otherwise should not be referenced by other classes.
visit(ArrowType.Null) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Struct) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.List) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.LargeList) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.FixedSizeList) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Union) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Map) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Int) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.FloatingPoint) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Utf8) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.LargeUtf8) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Binary) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.LargeBinary) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.FixedSizeBinary) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Bool) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Decimal) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Date) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Time) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Timestamp) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Interval) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Duration) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
 
visit(ArrowType.Null) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Struct) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.List) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.LargeList) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.FixedSizeList) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Union) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Map) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Int) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.FloatingPoint) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Utf8) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.LargeUtf8) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Binary) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.LargeBinary) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.FixedSizeBinary) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Bool) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Decimal) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Date) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Time) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Timestamp) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Interval) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(ArrowType.Duration) - Method in class org.apache.arrow.driver.jdbc.utils.AvaticaParameterBinder.BinderVisitor
 
visit(BaseFixedWidthVector, Range) - Method in class org.apache.arrow.vector.compare.ApproxEqualsVisitor
 
visit(BaseFixedWidthVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(BaseVariableWidthVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(BaseLargeVariableWidthVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(ListVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(FixedSizeListVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(LargeListVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(NonNullableStructVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(UnionVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(DenseUnionVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(NullVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(ExtensionTypeVector<?>, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
 
visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(ListVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(UnionVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(NullVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
 
visit(BaseFixedWidthVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(BaseVariableWidthVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(BaseLargeVariableWidthVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(ListVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(FixedSizeListVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(LargeListVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(NonNullableStructVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(UnionVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(DenseUnionVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(NullVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(ExtensionTypeVector<?>, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
 
visit(ArrowDictionaryBatch) - Method in interface org.apache.arrow.vector.ipc.message.ArrowMessage.ArrowMessageVisitor
 
visit(ArrowRecordBatch) - Method in interface org.apache.arrow.vector.ipc.message.ArrowMessage.ArrowMessageVisitor
 
visit(ArrowType.Null) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Struct) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.List) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.LargeList) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.FixedSizeList) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Union) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Map) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Int) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.FloatingPoint) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Utf8) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.LargeUtf8) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Binary) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.LargeBinary) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.FixedSizeBinary) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Bool) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Decimal) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Date) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Time) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Timestamp) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Interval) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.Duration) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.ExtensionType) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
 
visit(ArrowType.PrimitiveType) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Null) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Int) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.FloatingPoint) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Utf8) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.LargeUtf8) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Binary) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.LargeBinary) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.FixedSizeBinary) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Bool) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Decimal) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Date) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Time) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Timestamp) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Interval) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.Duration) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
 
visit(ArrowType.ComplexType) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
visit(ArrowType.Struct) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
visit(ArrowType.List) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
visit(ArrowType.LargeList) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
visit(ArrowType.FixedSizeList) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
visit(ArrowType.Union) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
visit(ArrowType.Map) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
 
visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(ListVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(UnionVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(NullVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
 
visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
 
visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
 
visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
 
visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 
visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
 

W

waitForListener(long) - Method in class org.apache.arrow.flight.BackpressureStrategy.CallbackBackpressureStrategy
 
waitForListener(long) - Method in interface org.apache.arrow.flight.BackpressureStrategy
Waits for the listener to be ready or cancelled up to the given timeout.
wasNull - Variable in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
wasNull() - Method in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
wasNull() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.ArrowFlightJdbcNullVectorAccessor
 
wasNull() - Method in class org.apache.arrow.driver.jdbc.accessor.impl.complex.AbstractArrowFlightJdbcUnionVectorAccessor
 
wasNullConsumer - Variable in class org.apache.arrow.driver.jdbc.accessor.ArrowFlightJdbcAccessor
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.BigIntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.BitHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.DateDayHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.DateMilliHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.Decimal256Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.DecimalHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.DurationHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.Float4Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.Float8Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.IntervalDayHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.IntervalMonthDayNanoHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.IntervalYearHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.IntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.LargeVarBinaryHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.LargeVarCharHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableBigIntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableBitHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableDateDayHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableDateMilliHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableDecimal256Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableDecimalHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableDurationHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableFloat4Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableFloat8Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableIntervalDayHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableIntervalMonthDayNanoHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableIntervalYearHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableIntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableLargeVarBinaryHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableLargeVarCharHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableSmallIntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeMicroHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeMilliHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeNanoHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeSecHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampMicroHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampMicroTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampMilliHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampMilliTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampNanoHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampNanoTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampSecHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTimeStampSecTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableTinyIntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableUInt1Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableUInt2Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableUInt4Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableUInt8Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableVarBinaryHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableVarCharHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.SmallIntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeMicroHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeMilliHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeNanoHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeSecHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampMicroHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampMicroTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampMilliHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampMilliTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampNanoHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampNanoTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampSecHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TimeStampSecTZHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.TinyIntHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.UInt1Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.UInt2Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.UInt4Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.UInt8Holder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.VarBinaryHolder
 
WIDTH - Static variable in class org.apache.arrow.vector.holders.VarCharHolder
 
withBufferAllocator(BufferAllocator) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the BufferAllocator to use in this handler.
withCallOptions(CallOption...) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Adds the provided CallOptions to this handler.
withCallOptions(Collection<CallOption>) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Adds the provided CallOptions to this handler.
withCause(Throwable) - Method in class org.apache.arrow.flight.CallStatus
Return a copy of this status with the given exception as the cause.
withClientCertificate(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the mTLS client certificate path (if mTLS is required).
withClientKey(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the mTLS client certificate private key path (if mTLS is required).
withDescription(String) - Method in class org.apache.arrow.flight.CallStatus
Return a copy of this status with an error message.
withDisableCertificateVerification(boolean) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets whether to disable the certificate verification in this handler.
withEncryption(boolean) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets whether to use TLS encryption in this handler.
withFlightSqlServerArrowVersion(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.FLIGHT_SQL_SERVER_ARROW_VERSION in the builder.
withFlightSqlServerCancel(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for query cancellation support.
withFlightSqlServerName(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.FLIGHT_SQL_SERVER_NAME in the builder.
withFlightSqlServerReadOnly(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.FLIGHT_SQL_SERVER_READ_ONLY in the builder.
withFlightSqlServerSql(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for SQL support.
withFlightSqlServerStatementTimeout(int) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for statement timeouts.
withFlightSqlServerSubstrait(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for Substrait support.
withFlightSqlServerSubstraitMaxVersion(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for Substrait maximum version support.
withFlightSqlServerSubstraitMinVersion(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for Substrait minimum version support.
withFlightSqlServerTransaction(FlightSql.SqlSupportedTransaction) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for transaction support.
withFlightSqlServerTransactionTimeout(int) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Set a value for transaction timeouts.
withFlightSqlServerVersion(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.FLIGHT_SQL_SERVER_VERSION in the builder.
withHost(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the host for this handler.
withMetadata(ErrorFlightMetadata) - Method in class org.apache.arrow.flight.CallStatus
Return a copy of this status with associated exception metadata.
withMiddlewareFactories(FlightClientMiddleware.Factory...) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Adds the provided factories to the list of ArrowFlightSqlClientHandler.Builder.middlewareFactories of this handler.
withMiddlewareFactories(Collection<FlightClientMiddleware.Factory>) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Adds the provided factories to the list of ArrowFlightSqlClientHandler.Builder.middlewareFactories of this handler.
withPassword(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the password for this handler.
withPort(int) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the port for this handler.
withRetainAuth(boolean) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Indicates if bearer tokens negotiated should be re-used by connections spawned for getStreams() calls.
withRetainCookies(boolean) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Indicates if cookies should be re-used by connections spawned for getStreams() calls.
withSqlAnsi92SupportedLevel(FlightSql.SupportedAnsi92SqlGrammarLevel...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_ANSI92_SUPPORTED_LEVEL in the builder.
withSqlBatchUpdatesSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_BATCH_UPDATES_SUPPORTED in the builder.
withSqlCatalogAtStart(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_CATALOG_AT_START in the builder.
withSqlCatalogsSupportedActions(FlightSql.SqlSupportedElementActions...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_CATALOGS_SUPPORTED_ACTIONS in the builder.
withSqlCatalogTerm(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_CATALOG_TERM in the builder.
withSqlCorrelatedSubqueriesSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlDataDefinitionCausesTransactionCommit(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlDataDefinitionsInTransactionsIgnored(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlDatetimeFunctions(String[]) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_DATETIME_FUNCTIONS in the builder.
withSqlDbSchemaNameLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_DB_SCHEMA_NAME_LENGTH in the builder.
withSqlDdlCatalog(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_DDL_CATALOG in the builder.
withSqlDdlSchema(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_DDL_SCHEMA in the builder.
withSqlDdlTable(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_DDL_TABLE in the builder.
withSqlDefaultTransactionIsolation(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlExtraNameCharacters(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_EXTRA_NAME_CHARACTERS in the builder.
withSqlIdentifierCase(FlightSql.SqlSupportedCaseSensitivity) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_IDENTIFIER_CASE in the builder.
withSqlIdentifierQuoteChar(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_IDENTIFIER_QUOTE_CHAR in the builder.
withSqlKeywords(String[]) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_KEYWORDS in the builder.
withSqlLocatorsUpdateCopy(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_LOCATORS_UPDATE_COPY in the builder.
withSqlMaxBinaryLiteralLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value SqlInf @link SqlInfo#SQL_MAX_BINARY_LITERAL_LENGTH} in the builder.
withSqlMaxCatalogNameLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_CATALOG_NAME_LENGTH in the builder.
withSqlMaxCharLiteralLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_CHAR_LITERAL_LENGTH in the builder.
withSqlMaxColumnNameLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_COLUMN_NAME_LENGTH in the builder.
withSqlMaxColumnsInGroupBy(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_COLUMNS_IN_GROUP_BY in the builder.
withSqlMaxColumnsInIndex(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_COLUMNS_IN_INDEX in the builder.
withSqlMaxColumnsInOrderBy(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_COLUMNS_IN_ORDER_BY in the builder.
withSqlMaxColumnsInSelect(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_COLUMNS_IN_SELECT in the builder.
withSqlMaxConnections(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_CONNECTIONS in the builder.
withSqlMaxCursorNameLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_CURSOR_NAME_LENGTH in the builder.
withSqlMaxIndexLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_INDEX_LENGTH in the builder.
withSqlMaxProcedureNameLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_PROCEDURE_NAME_LENGTH in the builder.
withSqlMaxRowSize(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_ROW_SIZE in the builder.
withSqlMaxRowSizeIncludesBlobs(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_ROW_SIZE_INCLUDES_BLOBS in the builder.
withSqlMaxStatementLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_STATEMENT_LENGTH in the builder.
withSqlMaxStatements(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_STATEMENTS in the builder.
withSqlMaxTableNameLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_TABLE_NAME_LENGTH in the builder.
withSqlMaxTablesInSelect(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_TABLES_IN_SELECT in the builder.
withSqlMaxUsernameLength(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_MAX_USERNAME_LENGTH in the builder.
withSqlNamedParametersSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_NAMED_PARAMETERS_SUPPORTED in the builder.
withSqlNullPlusNullIsNull(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_NULL_PLUS_NULL_IS_NULL in the builder.
withSqlNumericFunctions(String[]) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_NUMERIC_FUNCTIONS in the builder.
withSqlOuterJoinSupportLevel(FlightSql.SqlOuterJoinsSupportLevel...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_OUTER_JOINS_SUPPORT_LEVEL in the builder.
withSqlProcedureTerm(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_PROCEDURE_TERM in the builder.
withSqlQuotedIdentifierCase(FlightSql.SqlSupportedCaseSensitivity) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_QUOTED_IDENTIFIER_CASE in the builder.
withSqlSavepointsSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for { @link SqlInfo#SQL_SAVEPOINTS_SUPPORTED} in the builder.
withSqlSchemasSupportedActions(FlightSql.SqlSupportedElementActions...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SCHEMAS_SUPPORTED_ACTIONS in the builder.
withSqlSchemaTerm(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SCHEMA_TERM in the builder.
withSqlSearchStringEscape(String) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SEARCH_STRING_ESCAPE in the builder.
withSqlSelectForUpdateSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SELECT_FOR_UPDATE_SUPPORTED in the builder.
withSqlStoredFunctionsUsingCallSyntaxSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlStoredProceduresSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_STORED_PROCEDURES_SUPPORTED in the builder.
withSqlStringFunctions(String[]) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_STRING_FUNCTIONS in the builder.
withSqlSubQueriesSupported(FlightSql.SqlSupportedSubqueries...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTED_SUBQUERIES in the builder.
withSqlSupportedGrammar(FlightSql.SupportedSqlGrammar...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTED_GRAMMAR in the builder.
withSqlSupportedGroupBy(FlightSql.SqlSupportedGroupBy...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTED_GROUP_BY in the builder.
withSqlSupportedPositionedCommands(FlightSql.SqlSupportedPositionedCommands...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlSupportedResultSetTypes(FlightSql.SqlSupportedResultSetType...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTED_RESULT_SET_TYPES in the builder.
withSqlSupportedTransactionsIsolationLevels(FlightSql.SqlTransactionIsolationLevel...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlSupportedUnions(FlightSql.SqlSupportedUnions...) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTED_UNIONS in the builder.
withSqlSupportsColumnAliasing(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTS_COLUMN_ALIASING in the builder.
withSqlSupportsConvert(Map<Integer, List<Integer>>) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTS_CONVERT in the builder.
withSqlSupportsDifferentTableCorrelationNames(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlSupportsExpressionsInOrderBy(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlSupportsIntegrityEnhancementFacility(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlSupportsLikeEscapeClause(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTS_LIKE_ESCAPE_CLAUSE in the builder.
withSqlSupportsNonNullableColumns(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlSupportsOrderByUnrelated(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SUPPORTS_ORDER_BY_UNRELATED in the builder.
withSqlSupportsTableCorrelationNames(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
withSqlSystemFunctions(String[]) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_SYSTEM_FUNCTIONS in the builder.
withSqlTransactionsSupported(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
Sets a value for FlightSql.SqlInfo.SQL_TRANSACTIONS_SUPPORTED in the builder.
withSystemTrustStore(boolean) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets whether to use the certificates from the operating system.
withTlsRootCertificates(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the TLS root certificate path as an alternative to using the System or other Trust Store.
withToken(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the token used in the token authentication.
withTrustStorePassword(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the KeyStore password for this handler.
withTrustStorePath(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the KeyStore path for this handler.
withUsername(String) - Method in class org.apache.arrow.driver.jdbc.client.ArrowFlightSqlClientHandler.Builder
Sets the username for this handler.
wrap(Properties) - Method in enum org.apache.arrow.driver.jdbc.utils.ArrowFlightConnectionConfigImpl.ArrowFlightConnectionProperty
 
wrapForeignAllocation(ForeignAllocation) - Method in interface org.apache.arrow.memory.BufferAllocator
EXPERIMENTAL: Wrap an allocation created outside this BufferAllocator.
wrapHandshake(ServerAuthHandler, StreamObserver<Flight.HandshakeResponse>, ExecutorService) - Static method in class org.apache.arrow.flight.auth.ServerAuthWrapper
Wrap the auth handler for handshake purposes.
wrapIterator(Iterator<FROM>, Function<? super FROM, ? extends TO>) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
Maps a transformation function to the elements of an iterator, while wrapping exceptions in FlightRuntimeException.
wrapStub(T) - Method in interface org.apache.arrow.flight.CallOptions.GrpcCallOption
 
wrapStub(T) - Method in class org.apache.arrow.flight.grpc.CredentialCallOption
 
wrapStub(T) - Method in class org.apache.arrow.flight.HeaderCallOption
 
writableBytes() - Method in class org.apache.arrow.memory.ArrowBuf
Returns the number of bytes still available to write into this buffer before capacity is reached.
write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
write(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
write(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
write(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
write(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
write(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
write(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
write(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
write(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
write(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
write(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
write(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
write(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
write(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
write(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
write(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
write(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
write(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
write(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
write(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
write(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
write(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
write(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
write(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
write(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
write(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
write(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
write(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
write(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
write(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
write(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
write(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
write(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
write(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
write(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
write(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
write(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
write(BigIntHolder) - Method in interface org.apache.arrow.vector.complex.writer.BigIntWriter
 
write(BitHolder) - Method in interface org.apache.arrow.vector.complex.writer.BitWriter
 
write(DateDayHolder) - Method in interface org.apache.arrow.vector.complex.writer.DateDayWriter
 
write(DateMilliHolder) - Method in interface org.apache.arrow.vector.complex.writer.DateMilliWriter
 
write(Decimal256Holder) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
 
write(DecimalHolder) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
 
write(DurationHolder) - Method in interface org.apache.arrow.vector.complex.writer.DurationWriter
 
write(FixedSizeBinaryHolder) - Method in interface org.apache.arrow.vector.complex.writer.FixedSizeBinaryWriter
 
write(Float4Holder) - Method in interface org.apache.arrow.vector.complex.writer.Float4Writer
 
write(Float8Holder) - Method in interface org.apache.arrow.vector.complex.writer.Float8Writer
 
write(IntervalDayHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntervalDayWriter
 
write(IntervalMonthDayNanoHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntervalMonthDayNanoWriter
 
write(IntervalYearHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntervalYearWriter
 
write(IntHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntWriter
 
write(LargeVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
 
write(LargeVarCharHolder) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarCharWriter
 
write(SmallIntHolder) - Method in interface org.apache.arrow.vector.complex.writer.SmallIntWriter
 
write(TimeMicroHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeMicroWriter
 
write(TimeMilliHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeMilliWriter
 
write(TimeNanoHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeNanoWriter
 
write(TimeSecHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeSecWriter
 
write(TimeStampMicroTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMicroTZWriter
 
write(TimeStampMicroHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMicroWriter
 
write(TimeStampMilliTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMilliTZWriter
 
write(TimeStampMilliHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMilliWriter
 
write(TimeStampNanoTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampNanoTZWriter
 
write(TimeStampNanoHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampNanoWriter
 
write(TimeStampSecTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampSecTZWriter
 
write(TimeStampSecHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampSecWriter
 
write(TinyIntHolder) - Method in interface org.apache.arrow.vector.complex.writer.TinyIntWriter
 
write(UInt1Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt1Writer
 
write(UInt2Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt2Writer
 
write(UInt4Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt4Writer
 
write(UInt8Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt8Writer
 
write(VarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
 
write(VarCharHolder) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
 
write(VectorSchemaRoot) - Method in class org.apache.arrow.vector.ipc.JsonFileWriter
Writes the record batch to the JSON file.
write(byte[]) - Method in class org.apache.arrow.vector.ipc.WriteChannel
 
write(ByteBuffer) - Method in class org.apache.arrow.vector.ipc.WriteChannel
Writes all data from buffer to the underlying channel.
write(ArrowBuf) - Method in class org.apache.arrow.vector.ipc.WriteChannel
Writes the buffer to the underlying channel.
write(FBSerializable, boolean) - Method in class org.apache.arrow.vector.ipc.WriteChannel
Writes the serialized flatbuffer to the underlying channel.
write(ByteBuffer) - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
 
write_legacy_ipc_format - Variable in class org.apache.arrow.vector.ipc.message.IpcOption
 
writeAllStructsToVector(FlatBufferBuilder, List<? extends FBSerializable>) - Static method in class org.apache.arrow.vector.ipc.message.FBSerializables
Writes every element of all to builder and calls FlatBufferBuilder.endVector() afterwards.
writeBatch() - Method in class org.apache.arrow.vector.ipc.ArrowWriter
Writes the record batch currently loaded in this instance's VectorSchemaRoot.
writeBatchBuffers(WriteChannel, ArrowRecordBatch) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Write the Arrow buffers of the record batch to the output channel.
writeBigDecimalToArrowBuf(BigDecimal, ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Write the given BigDecimal to the ArrowBuf at the given value index.
writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
writeBigEndianBytesToDecimal(byte[]) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
 
writeBigEndianBytesToDecimal(byte[]) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
Deprecated.
Use either the version that additionally takes in an ArrowType or use the holder version. This version does not contain enough information to fully specify this field type.
writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
writeBigEndianBytesToDecimal256(byte[]) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
 
writeBigEndianBytesToDecimal256(byte[]) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
Deprecated.
Use either the version that additionally takes in an ArrowType or use the holder version. This version does not contain enough information to fully specify this field type.
writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
writeBigInt(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeBigInt(long) - Method in interface org.apache.arrow.vector.complex.writer.BigIntWriter
 
writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
writeBit(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeBit(int) - Method in interface org.apache.arrow.vector.complex.writer.BitWriter
 
writeByte(byte) - Method in class org.apache.arrow.memory.ArrowBuf
Set the provided byte value at the writerIndex.
writeByte(int) - Method in class org.apache.arrow.memory.ArrowBuf
Set the lower order byte for the provided value at the writerIndex.
writeByteArrayToArrowBuf(byte[], ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Write the given byte array to the ArrowBuf at the given value index.
writeBytes(byte[]) - Method in class org.apache.arrow.memory.ArrowBuf
Write the bytes from given byte array into this ArrowBuf starting at writerIndex.
writeBytes(byte[], int, int) - Method in class org.apache.arrow.memory.ArrowBuf
Write the bytes from given byte array starting at srcIndex into this ArrowBuf starting at writerIndex.
WriteChannel - Class in org.apache.arrow.vector.ipc
Wrapper around a WritableByteChannel that maintains the position as well adding some common serialization utilities.
WriteChannel(WritableByteChannel) - Constructor for class org.apache.arrow.vector.ipc.WriteChannel
 
writeChar(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
writeDateDay(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeDateDay(int) - Method in interface org.apache.arrow.vector.complex.writer.DateDayWriter
 
writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
writeDateMilli(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeDateMilli(long) - Method in interface org.apache.arrow.vector.complex.writer.DateMilliWriter
 
writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
writeDecimal(long, ArrowBuf, byte, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeDecimal(long, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeDecimal(long, ArrowBuf, ArrowType) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
 
writeDecimal(BigDecimal) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
 
writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
writeDecimal256(long, ArrowBuf, byte, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeDecimal256(long, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeDecimal256(long, ArrowBuf, ArrowType) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
 
writeDecimal256(BigDecimal) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
 
writeDictionaryBatch(ArrowDictionaryBatch) - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
 
writeDictionaryBatch(Dictionary) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
writeDictionaryBatch(ArrowDictionaryBatch) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
writeDouble(double) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
writeDouble(double) - Method in class org.apache.arrow.memory.ArrowBuf
Set the provided double value at the writerIndex.
writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeDuration(long) - Method in interface org.apache.arrow.vector.complex.writer.DurationWriter
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeEndOfStream(WriteChannel, IpcOption) - Static method in class org.apache.arrow.vector.ipc.ArrowStreamWriter
Write an EOS identifier to the WriteChannel.
writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeFixedSizeBinary(ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.FixedSizeBinaryWriter
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeFloat(float) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
writeFloat(float) - Method in class org.apache.arrow.memory.ArrowBuf
Set the provided float value at the writerIndex.
writeFloat4(float, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeFloat4(float) - Method in interface org.apache.arrow.vector.complex.writer.Float4Writer
 
writeFloat8(double, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeFloat8(double) - Method in interface org.apache.arrow.vector.complex.writer.Float8Writer
 
writeInt(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
writeInt(int) - Method in class org.apache.arrow.memory.ArrowBuf
Set the provided int value at the writerIndex.
writeInt(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeInt(int) - Method in interface org.apache.arrow.vector.complex.writer.IntWriter
 
writeIntervalDay(int, int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeIntervalDay(int, int) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
writeIntervalDay(int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeIntervalDay(int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeIntervalDay(int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeIntervalDay(int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeIntervalDay(int, int) - Method in interface org.apache.arrow.vector.complex.writer.IntervalDayWriter
 
writeIntervalMonthDayNano(int, int, long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeIntervalMonthDayNano(int, int, long) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
writeIntervalMonthDayNano(int, int, long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeIntervalMonthDayNano(int, int, long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeIntervalMonthDayNano(int, int, long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeIntervalMonthDayNano(int, int, long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeIntervalMonthDayNano(int, int, long) - Method in interface org.apache.arrow.vector.complex.writer.IntervalMonthDayNanoWriter
 
writeIntervalYear(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeIntervalYear(int) - Method in interface org.apache.arrow.vector.complex.writer.IntervalYearWriter
 
writeIntLittleEndian(int) - Method in class org.apache.arrow.vector.ipc.WriteChannel
Writes v in little-endian format to the underlying channel.
writeKeyValues(FlatBufferBuilder, Map<String, String>) - Static method in class org.apache.arrow.vector.ipc.message.FBSerializables
Writes map data with string type.
writeLargeVarBinary(long, long, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarBinary(long, long, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
 
writeLargeVarBinary(byte[]) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
 
writeLargeVarBinary(byte[], int, int) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
 
writeLargeVarBinary(ByteBuffer) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
 
writeLargeVarBinary(ByteBuffer, int, int) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
 
writeLargeVarChar(long, long, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeLargeVarChar(long, long, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarCharWriter
 
writeLargeVarChar(Text) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarCharWriter
 
writeLargeVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarCharWriter
 
writeLong(long) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
writeLong(long) - Method in class org.apache.arrow.memory.ArrowBuf
Set the provided long value at the writerIndex.
writeLongToArrowBuf(long, ArrowBuf, int, int) - Static method in class org.apache.arrow.vector.util.DecimalUtility
Write the given long to the ArrowBuf at the given value index.
writeMessageBuffer(WriteChannel, int, ByteBuffer) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
 
writeMessageBuffer(WriteChannel, int, ByteBuffer, IpcOption) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
Write the serialized Message metadata, prefixed by the length, to the output Channel.
writeNull() - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
writeNull() - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
writeNull() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter
 
writer - Variable in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writer - Variable in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writer - Variable in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeRecordBatch(ArrowRecordBatch) - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
 
writeRecordBatch(ArrowRecordBatch) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
 
writerIndex(int) - Method in class io.netty.buffer.NettyArrowBuf
 
writerIndex() - Method in class org.apache.arrow.memory.ArrowBuf
Get the index at which next byte will be written to.
writerIndex(long) - Method in class org.apache.arrow.memory.ArrowBuf
Set the writer index for this ArrowBuf.
writeShort(int) - Method in class io.netty.buffer.UnsafeDirectLittleEndian
 
writeShort(int) - Method in class org.apache.arrow.memory.ArrowBuf
Set the provided int value as short at the writerIndex.
writeSmallInt(short, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
 
writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeSmallInt(short) - Method in interface org.apache.arrow.vector.complex.writer.SmallIntWriter
 
writeTimeMicro(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
 
writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeMicro(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeMicroWriter
 
writeTimeMilli(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
 
writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeMilli(int) - Method in interface org.apache.arrow.vector.complex.writer.TimeMilliWriter
 
writeTimeNano(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
 
writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeNano(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeNanoWriter
 
writeTimeSec(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
 
writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeSec(int) - Method in interface org.apache.arrow.vector.complex.writer.TimeSecWriter
 
writeTimeStampMicro(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
 
writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampMicro(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMicroWriter
 
writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
 
writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampMicroTZ(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMicroTZWriter
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeTimeStampMilli(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
 
writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampMilli(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMilliWriter
 
writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
 
writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampMilliTZ(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMilliTZWriter
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeTimeStampNano(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
 
writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampNano(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampNanoWriter
 
writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
 
writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampNanoTZ(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampNanoTZWriter
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeTimeStampSec(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
 
writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampSec(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampSecWriter
 
writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
 
writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTimeStampSecTZ(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampSecTZWriter
Deprecated.
The holder version should be used instead because the plain value version does not contain enough information to fully specify this field type.
writeTinyInt(byte, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
 
writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeTinyInt(byte) - Method in interface org.apache.arrow.vector.complex.writer.TinyIntWriter
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.Action
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.ActionType
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.Criteria
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.Empty
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.FlightData
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.Location
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.PutResult
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.Result
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.Ticket
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Perf
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.perf.impl.PerfOuterClass.Token
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
Deprecated.
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
Deprecated.
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
 
writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
 
writeTo(FlatBufferBuilder) - Method in class org.apache.arrow.vector.ipc.message.ArrowBlock
 
writeTo(FlatBufferBuilder) - Method in class org.apache.arrow.vector.ipc.message.ArrowBodyCompression
 
writeTo(FlatBufferBuilder) - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
 
writeTo(FlatBufferBuilder) - Method in class org.apache.arrow.vector.ipc.message.ArrowDictionaryBatch
 
writeTo(FlatBufferBuilder) - Method in class org.apache.arrow.vector.ipc.message.ArrowFieldNode
 
writeTo(FlatBufferBuilder) - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
 
writeTo(FlatBufferBuilder) - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
 
writeTo(FlatBufferBuilder) - Method in interface org.apache.arrow.vector.ipc.message.FBSerializable
Returns the number of bytes taken to serialize the data in builder after writing to it.
writeToBuilder(StringBuilder, int) - Method in class org.apache.arrow.memory.util.StackTrace
Write the stack trace to a StringBuilder.
writeUInt1(byte, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
 
writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeUInt1(byte) - Method in interface org.apache.arrow.vector.complex.writer.UInt1Writer
 
writeUInt2(char, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
 
writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeUInt2(char) - Method in interface org.apache.arrow.vector.complex.writer.UInt2Writer
 
writeUInt4(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
 
writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeUInt4(int) - Method in interface org.apache.arrow.vector.complex.writer.UInt4Writer
 
writeUInt8(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
 
writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeUInt8(long) - Method in interface org.apache.arrow.vector.complex.writer.UInt8Writer
 
writeUncompressedLength(ArrowBuf, long) - Method in class org.apache.arrow.vector.compression.AbstractCompressionCodec
 
writeVarBinary(int, int, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
 
writeVarBinary(int, int, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
 
writeVarBinary(byte[]) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
 
writeVarBinary(byte[], int, int) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
 
writeVarBinary(ByteBuffer) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
 
writeVarBinary(ByteBuffer, int, int) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
 
writeVarChar(int, int, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
 
writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
 
writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
 
writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
 
writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
 
writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
 
writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
 
writeVarChar(int, int, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
 
writeVarChar(Text) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
 
writeVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
 
writeZeros(long) - Method in class org.apache.arrow.vector.ipc.WriteChannel
Writes zeroCount zeros the underlying channel.

X

XDBC_BIGINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_BIGINT = -5;
XDBC_BINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_BINARY = -2;
XDBC_BIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_BIT = -7;
XDBC_CHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_CHAR = 1;
XDBC_DATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_DATE = 91;
XDBC_DATETIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_DATETIME = 9;
XDBC_DECIMAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_DECIMAL = 3;
XDBC_DOUBLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_DOUBLE = 8;
XDBC_FLOAT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_FLOAT = 6;
XDBC_INTEGER_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_INTEGER = 4;
XDBC_INTERVAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_INTERVAL = 10;
XDBC_LONGVARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_LONGVARBINARY = -4;
XDBC_LONGVARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_LONGVARCHAR = -1;
XDBC_NUMERIC_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_NUMERIC = 2;
XDBC_REAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_REAL = 7;
XDBC_SMALLINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_SMALLINT = 5;
XDBC_SUBCODE_DATE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_DATE = 1;
XDBC_SUBCODE_DATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_DATE = 1;
XDBC_SUBCODE_DAY - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_DAY = 3;
XDBC_SUBCODE_DAY_TO_HOUR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_DAY_TO_HOUR = 8;
XDBC_SUBCODE_DAY_TO_MINUTE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_DAY_TO_MINUTE = 9;
XDBC_SUBCODE_DAY_TO_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_DAY_TO_SECOND = 10;
XDBC_SUBCODE_DAY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_DAY = 3;
XDBC_SUBCODE_HOUR - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_HOUR = 4;
XDBC_SUBCODE_HOUR_TO_MINUTE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_HOUR_TO_MINUTE = 11;
XDBC_SUBCODE_HOUR_TO_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_HOUR_TO_SECOND = 12;
XDBC_SUBCODE_HOUR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_HOUR = 4;
XDBC_SUBCODE_INTERVAL_DAY_TO_HOUR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_DAY_TO_HOUR = 108;
XDBC_SUBCODE_INTERVAL_DAY_TO_MINUTE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_DAY_TO_MINUTE = 109;
XDBC_SUBCODE_INTERVAL_DAY_TO_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_DAY_TO_SECOND = 110;
XDBC_SUBCODE_INTERVAL_DAY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_DAY = 103;
XDBC_SUBCODE_INTERVAL_HOUR_TO_MINUTE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_HOUR_TO_MINUTE = 111;
XDBC_SUBCODE_INTERVAL_HOUR_TO_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_HOUR_TO_SECOND = 112;
XDBC_SUBCODE_INTERVAL_HOUR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_HOUR = 104;
XDBC_SUBCODE_INTERVAL_MINUTE_TO_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_MINUTE_TO_SECOND = 113;
XDBC_SUBCODE_INTERVAL_MINUTE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_MINUTE = 105;
XDBC_SUBCODE_INTERVAL_MONTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_MONTH = 102;
XDBC_SUBCODE_INTERVAL_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_SECOND = 106;
XDBC_SUBCODE_INTERVAL_YEAR_TO_MONTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_YEAR_TO_MONTH = 107;
XDBC_SUBCODE_INTERVAL_YEAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_INTERVAL_YEAR = 101;
XDBC_SUBCODE_MINUTE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_MINUTE = 5;
XDBC_SUBCODE_MINUTE_TO_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_MINUTE_TO_SECOND = 13;
XDBC_SUBCODE_MINUTE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_MINUTE = 5;
XDBC_SUBCODE_MONTH - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_MONTH = 2;
XDBC_SUBCODE_MONTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_MONTH = 2;
XDBC_SUBCODE_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_SECOND = 6;
XDBC_SUBCODE_TIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_TIME = 2;
XDBC_SUBCODE_TIME_WITH_TIMEZONE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_TIME_WITH_TIMEZONE = 4;
XDBC_SUBCODE_TIMESTAMP_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_TIMESTAMP = 3;
XDBC_SUBCODE_TIMESTAMP_WITH_TIMEZONE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_TIMESTAMP_WITH_TIMEZONE = 5;
XDBC_SUBCODE_UNKNOWN_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_UNKNOWN = 0;
XDBC_SUBCODE_YEAR_TO_MONTH_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_YEAR_TO_MONTH = 7;
XDBC_SUBCODE_YEAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
XDBC_SUBCODE_YEAR = 1;
XDBC_TIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_TIME = 92;
XDBC_TIMESTAMP_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_TIMESTAMP = 93;
XDBC_TINYINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_TINYINT = -6;
XDBC_UNKNOWN_TYPE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_UNKNOWN_TYPE = 0;
XDBC_VARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_VARBINARY = -3;
XDBC_VARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_VARCHAR = 12;
XDBC_WCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_WCHAR = -8;
XDBC_WVARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
XDBC_WVARCHAR = -9;

Y

YEAR_MONTH - Static variable in class org.apache.arrow.flatbuf.IntervalUnit
 
yearsToMonths - Static variable in class org.apache.arrow.vector.util.DateUtility
 

Z

zeroes - Static variable in class org.apache.arrow.vector.util.DecimalUtility
 
zeroVector() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
zero out the vector and the data in associated buffers.
zeroVector() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
zero out the vector and the data in associated buffers.
zeroVector() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
zero out the vector and the data in associated buffers.
zeroVector() - Method in interface org.apache.arrow.vector.FixedWidthVector
Zero out the underlying buffer backing this vector.
ZeroVector - Class in org.apache.arrow.vector
A zero length vector of any type.
ZeroVector(String) - Constructor for class org.apache.arrow.vector.ZeroVector
Instantiate a ZeroVector.
ZeroVector(String, FieldType) - Constructor for class org.apache.arrow.vector.ZeroVector
Instantiate a ZeroVector.
ZeroVector(Field) - Constructor for class org.apache.arrow.vector.ZeroVector
Instantiate a ZeroVector.
ZeroVector() - Constructor for class org.apache.arrow.vector.ZeroVector
Deprecated.
ZSTD - Static variable in class org.apache.arrow.flatbuf.CompressionType
 
ZstdCompressionCodec - Class in org.apache.arrow.compression
Compression codec for the ZSTD algorithm.
ZstdCompressionCodec() - Constructor for class org.apache.arrow.compression.ZstdCompressionCodec
 
ZstdCompressionCodec(int) - Constructor for class org.apache.arrow.compression.ZstdCompressionCodec
 

_

__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Binary
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Binary.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BinaryView
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BinaryView.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Block
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Block.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BodyCompression
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BodyCompression.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Bool
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Bool.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Buffer
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Buffer.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Date
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Date.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Decimal
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Decimal.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryBatch
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryBatch.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Duration
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Duration.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Field
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Field.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FieldNode
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FieldNode.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeList
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeList.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FloatingPoint
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FloatingPoint.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Footer
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Footer.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Int
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Int.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Interval
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Interval.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.KeyValue
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.KeyValue.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeBinary
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeBinary.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeList
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeList.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeListView
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeListView.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeUtf8
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeUtf8.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.List
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.List.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.ListView
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.ListView.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Map
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Map.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Message
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Message.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Null
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Null.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RecordBatch.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RunEndEncoded
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RunEndEncoded.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Schema
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Schema.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensor
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensor.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Struct_
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Struct_.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Tensor
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Tensor.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.TensorDim
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.TensorDim.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Time
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Time.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Timestamp
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Timestamp.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Union
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Union.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8.Vector
 
__assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8View
 
__assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8View.Vector
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Binary
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BinaryView
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Block
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BodyCompression
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Bool
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Buffer
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Date
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Decimal
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryBatch
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Duration
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Field
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FieldNode
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeList
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FloatingPoint
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Footer
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Int
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Interval
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.KeyValue
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeBinary
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeList
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeListView
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeUtf8
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.List
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.ListView
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Map
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Message
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Null
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RecordBatch
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RunEndEncoded
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Schema
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensor
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Struct_
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Tensor
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.TensorDim
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Time
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Timestamp
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Union
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8
 
__init(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8View
 
_getByte(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getInt(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getIntLE(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getLong(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getLongLE(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getShort(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getShortLE(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.NettyArrowBuf
 
_setByte(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
_setInt(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
_setIntLE(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
_setLong(int, long) - Method in class io.netty.buffer.NettyArrowBuf
 
_setLongLE(int, long) - Method in class io.netty.buffer.NettyArrowBuf
 
_setMedium(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
_setMediumLE(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
_setShort(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
_setShortLE(int, int) - Method in class io.netty.buffer.NettyArrowBuf
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

Copyright © 2024 The Apache Software Foundation. All rights reserved.