Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- 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.BaseVariableWidthViewVector
- 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.LargeListViewVector
- 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.ListViewVector
- 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.RunEndEncodedVector
-
Accept a generic
VectorVisitor
and return the result. - 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(VectorVisitor<OUT, IN>, IN) - Method in interface org.apache.arrow.vector.ValueVector
-
Accept a generic
VectorVisitor
and return the result. - 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.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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(ArrowType.ArrowTypeVisitor<T>) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8View
- 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.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 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 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 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
- acceptPutStatementBulkIngest(FlightSql.CommandStatementIngest, FlightProducer.CallContext, FlightStream, FlightProducer.StreamListener<PutResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Accepts uploaded data for a particular bulk ingest data stream.
- acceptPutStatementBulkIngest(FlightSql.CommandStatementIngest, 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 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
- acceptVisitor(SessionOptionValueVisitor<T>) - Method in class org.apache.arrow.flight.SessionOptionValue
-
Value access via a caller-provided visitor/functor.
- 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(int) - Method in interface org.apache.arrow.memory.AllocationReservation
-
Deprecated, for removal: This API element is subject to removal in a future version.
- add(long) - Method in interface org.apache.arrow.memory.AllocationReservation
-
Add to the current reservation.
- 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(String, FieldType) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
- add(T) - Method in class org.apache.arrow.util.AutoCloseables.RollbackCloseable
- 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.
- addAllValues(Iterable<String>) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- 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
- 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
- addEndianness(FlatBufferBuilder, short) - Static method in class org.apache.arrow.flatbuf.Schema
- addEndpoint(int, 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.Builder) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
-
A list of endpoints associated with the flight.
- addEndpoint(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.
- 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(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(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().
- 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(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.adapter.avro.consumers.BaseAvroConsumer
- addNull() - Method in interface org.apache.arrow.adapter.avro.consumers.Consumer
-
Add null value to vector by making writer position + 1.
- addNull() - Method in class org.apache.arrow.adapter.avro.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
- addOrGetListView(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 it 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.BaseLargeRepeatedValueViewVector
-
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.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.BaseRepeatedValueViewVector
-
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.LargeListViewVector
- addOrGetVector(FieldType) - Method in class org.apache.arrow.vector.complex.ListVector
-
Initialize the child data vector to field type.
- addOrGetVector(FieldType) - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
-
Deprecated.
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
-
Deprecated.
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- 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
- 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
- addTo(Temporal) - Method in class org.apache.arrow.vector.PeriodDuration
- 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(FlatBufferBuilder, int) - Static method in class org.apache.arrow.flatbuf.KeyValue
- 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.
- addValues(String) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- 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.
- addValuesBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- 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(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.
- addVector(FieldVector) - Method in class org.apache.arrow.vector.complex.UnionVector
- addVectorAsNullable - Variable in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- 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(Collection<? extends AutoCloseable>) - Static method in class org.apache.arrow.util.AutoCloseables
-
Returns a new
AutoCloseable
that callsAutoCloseables.close(Iterable)
onautoCloseables
when close is called. - ALL - Static variable in class org.apache.arrow.flight.Criteria
- 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.Float2WriterImpl
- 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.PromotableViewWriter
- 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.UnionLargeListViewWriter
- allocate() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- allocate() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- allocate() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- allocate() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ComplexWriter
- allocate() - Method in interface org.apache.arrow.vector.complex.writer.FieldWriter
- 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.
- allocateBuffer() - Method in interface org.apache.arrow.memory.AllocationReservation
-
Allocate a buffer whose size is the total of all the add()s made.
- allocateBuffers(long) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- allocateBuffers(long) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- allocateMemory(long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- allocateNew() - Method in class org.apache.arrow.vector.BaseFixedWidthVector
- allocateNew() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- allocateNew() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
- allocateNew() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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
-
Same as
LargeListVector.allocateNewSafe()
. - allocateNew() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- allocateNew() - Method in class org.apache.arrow.vector.complex.ListVector
-
Same as
ListVector.allocateNewSafe()
. - allocateNew() - Method in class org.apache.arrow.vector.complex.ListViewVector
- allocateNew() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Allocate new buffers.
- allocateNew() - Method in class org.apache.arrow.vector.complex.UnionVector
- allocateNew() - Method in class org.apache.arrow.vector.ExtensionTypeVector
- allocateNew() - Method in class org.apache.arrow.vector.NullVector
- allocateNew() - Method in interface org.apache.arrow.vector.ValueVector
-
Allocate new buffers.
- allocateNew() - Method in class org.apache.arrow.vector.VectorSchemaRoot
-
Do an adaptive allocation of each vector for memory purposes.
- 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(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- allocateNew(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
- allocateNew(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- allocateNew(int) - Method in interface org.apache.arrow.vector.FixedWidthVector
-
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(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(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(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(long, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Allocate memory for the vector to support storing at least the provided number of elements in the vector.
- allocateNew(long, int) - Method in interface org.apache.arrow.vector.VariableWidthVector
-
Allocate a new memory space for this vector.
- 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.
- 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.BaseVariableWidthViewVector
-
Allocate memory for the vector.
- allocateNewSafe() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
- allocateNewSafe() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- allocateNewSafe() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- allocateNewSafe() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.LargeListViewVector
- allocateNewSafe() - Method in class org.apache.arrow.vector.complex.ListVector
-
Allocate memory for the vector.
- allocateNewSafe() - Method in class org.apache.arrow.vector.complex.ListViewVector
- allocateNewSafe() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Allocates new buffers.
- 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
- allocateOrGetLastDataBuffer(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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.LargeListViewVector
- allocateValidityBuffer(long) - Method in class org.apache.arrow.vector.complex.ListVector
- allocateValidityBuffer(long) - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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 - 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
- allocator(BufferAllocator) - Method in class org.apache.arrow.flight.FlightClient.Builder
- allocator(BufferAllocator) - Method in class org.apache.arrow.flight.FlightServer.Builder
- 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 - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The operation creates a resource that already exists.
- ALREADY_EXISTS - Static variable in class org.apache.arrow.flight.CallStatus
- ANSI92_ENTRY_SQL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
-
ANSI92_ENTRY_SQL = 0;
- ANSI92_ENTRY_SQL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
-
ANSI92_ENTRY_SQL = 0;
- ANSI92_FULL_SQL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
-
ANSI92_FULL_SQL = 2;
- ANSI92_FULL_SQL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
-
ANSI92_FULL_SQL = 2;
- ANSI92_INTERMEDIATE_SQL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
-
ANSI92_INTERMEDIATE_SQL = 1;
- 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(boolean, VectorSchemaRoot, VectorSchemaRoot...) - Static method in class org.apache.arrow.vector.util.VectorSchemaRootAppender
-
Appends a number of
VectorSchemaRoot
s. - 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(VectorSchemaRoot, VectorSchemaRoot...) - Static method in class org.apache.arrow.vector.util.VectorSchemaRootAppender
-
Appends a number of
VectorSchemaRoot
s. - 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.adapter.avro.consumers.SkipFunction
- applyRequestMetadata(CallCredentials.RequestInfo, Executor, CallCredentials.MetadataApplier) - Method in class org.apache.arrow.flight.grpc.CallCredentialAdapter
- 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.
- 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.
- 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.
- 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.
- 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 - 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(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.
- ArrowBufPointer(ArrowBufHasher) - Constructor for class org.apache.arrow.memory.util.ArrowBufPointer
-
Constructs an arrow buffer pointer with the specified hasher.
- ArrowDictionaryBatch - Class in org.apache.arrow.vector.ipc.message
-
POJO wrapper around a Dictionary Batch IPC messages.
- 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(SeekableByteChannel, BufferAllocator) - 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(SeekableReadChannel, BufferAllocator, CompressionCodec.Factory) - 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, 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
- ArrowFileWriter(VectorSchemaRoot, DictionaryProvider, WritableByteChannel, IpcOption) - Constructor for class org.apache.arrow.vector.ipc.ArrowFileWriter
- ArrowFooter - Class in org.apache.arrow.vector.ipc.message
-
Footer metadata for the arrow file format.
- ArrowFooter(Footer) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowFooter
-
Constructs from the corresponding Flatbuffer message.
- 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.
- 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.
- ArrowRecordBatch(int, List<ArrowFieldNode>, List<ArrowBuf>, ArrowBodyCompression, List<Long>, boolean) - Constructor for class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
-
Construct a record batch from nodes.
- ArrowRecordBatch(int, List<ArrowFieldNode>, List<ArrowBuf>, ArrowBodyCompression, List<Long>, 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(InputStream, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
-
Constructs a streaming reader from an InputStream.
- ArrowStreamReader(InputStream, 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(ReadableByteChannel, BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
-
Constructs a streaming reader from a ReadableByteChannel input.
- ArrowStreamReader(MessageChannelReader, BufferAllocator) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
-
Constructs a streaming reader using a MessageChannelReader.
- ArrowStreamReader(MessageChannelReader, BufferAllocator, CompressionCodec.Factory) - Constructor for class org.apache.arrow.vector.ipc.ArrowStreamReader
-
Constructs a streaming reader using a MessageChannelReader.
- 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.BinaryView - 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.LargeListView - 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.ListView - 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.RunEndEncoded - Class in org.apache.arrow.vector.types.pojo
- 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
- ArrowType.Utf8View - 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() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asBigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asBigInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asBit() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asBit() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asBit(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asDateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asDateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asDateDay(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asDateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asDateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asDateMilli(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asDecimal(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asDecimal(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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.UnionViewWriter
- asDecimal256(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asDuration(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asDuration(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asFixedSizeBinary(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asFixedSizeBinary(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asFloat2() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asFloat2() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asFloat2(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asFloat4() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asFloat4() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asFloat4(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asFloat8() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asFloat8() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asFloat8(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asImmutableList(V...) - Static method in class org.apache.arrow.util.Collections2
-
Copies the values to a new unmodifiable list.
- asInt() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asIntervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asIntervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asIntervalDay(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asIntervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asIntervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asIntervalMonthDayNano(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asIntervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asIntervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asIntervalYear(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asLargeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asLargeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asLargeVarBinary(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asLargeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asLargeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asLargeVarChar(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asList() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asList(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asListView() - 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 class org.apache.arrow.memory.RootAllocator
- assertOpen() - Method in interface org.apache.arrow.memory.BufferAllocator
-
Asserts (using java assertions) that the provided allocator is currently open.
- asSmallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asSmallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asSmallInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asStruct() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asStruct(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeMicro(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeMilli(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeNano(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeSec(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeStampMicro(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeStampMicroTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampMicroTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeStampMilli(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeStampMilliTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampMilliTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeStampNano(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeStampNanoTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampNanoTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTimeStampSec(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asTimeStampSecTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTimeStampSecTZ(ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asTinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asUInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asUInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asUInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asUInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asUInt2(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asUInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asUInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asUInt4(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asUInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asUInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asUInt8(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asVarBinary(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asVarChar(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asViewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asViewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asViewVarBinary(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- asViewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- asViewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- asViewVarChar(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- 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(ClientAuthHandler.ClientAuthSender, Iterator<byte[]>) - Method in interface org.apache.arrow.flight.auth.ClientAuthHandler
-
Deprecated.Handle the initial handshake with the server.
- authenticate(ClientAuthHandler, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Authenticates against the Flight service.
- authenticate(ServerAuthHandler.ServerAuthSender, Iterator<byte[]>) - Method in class org.apache.arrow.flight.auth.BasicServerAuthHandler
- 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.
- 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.
- AvroArraysConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume array type values from avro decoder.
- AvroArraysConsumer(ListVector, Consumer) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroArraysConsumer
-
Instantiate a ArrayConsumer.
- AvroBooleanConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume boolean type values from avro decoder.
- AvroBooleanConsumer(BitVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroBooleanConsumer
-
Instantiate a AvroBooleanConsumer.
- AvroBytesConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume bytes type values from avro decoder.
- AvroBytesConsumer(VarBinaryVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroBytesConsumer
-
Instantiate a AvroBytesConsumer.
- AvroDateConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer which consume date type values from avro decoder.
- AvroDateConsumer(DateDayVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.logical.AvroDateConsumer
-
Instantiate a AvroDateConsumer.
- AvroDecimalConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer which consume decimal type values from avro decoder.
- AvroDecimalConsumer(DecimalVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.logical.AvroDecimalConsumer
-
Instantiate a AvroDecimalConsumer.
- AvroDecimalConsumer.BytesDecimalConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer for decimal logical type with original bytes type.
- AvroDecimalConsumer.FixedDecimalConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer for decimal logical type with original fixed type.
- AvroDoubleConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume double type values from avro decoder.
- AvroDoubleConsumer(Float8Vector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroDoubleConsumer
-
Instantiate a AvroDoubleConsumer.
- AvroEnumConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume enum type values from avro decoder.
- AvroEnumConsumer(BaseIntVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroEnumConsumer
-
Instantiate a AvroEnumConsumer.
- AvroFixedConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume fixed type values from avro decoder.
- AvroFixedConsumer(FixedSizeBinaryVector, int) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroFixedConsumer
-
Instantiate a AvroFixedConsumer.
- AvroFloatConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume float type values from avro decoder.
- AvroFloatConsumer(Float4Vector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroFloatConsumer
-
Instantiate a AvroFloatConsumer.
- AvroIntConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume int type values from avro decoder.
- AvroIntConsumer(IntVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroIntConsumer
-
Instantiate a AvroIntConsumer.
- AvroLongConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume long type values from avro decoder.
- AvroLongConsumer(BigIntVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroLongConsumer
-
Instantiate a AvroLongConsumer.
- AvroMapConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume map type values from avro decoder.
- AvroMapConsumer(MapVector, Consumer) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroMapConsumer
-
Instantiate a AvroMapConsumer.
- AvroNullConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume null type values from avro decoder.
- AvroNullConsumer(NullVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroNullConsumer
- AvroStringConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume string type values from avro decoder.
- AvroStringConsumer(VarCharVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroStringConsumer
-
Instantiate a AvroStringConsumer.
- AvroStructConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume nested record type values from avro decoder.
- AvroStructConsumer(StructVector, Consumer[]) - Constructor for class org.apache.arrow.adapter.avro.consumers.AvroStructConsumer
-
Instantiate a AvroStructConsumer.
- AvroTimeMicroConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer which consume date time-micro values from avro decoder.
- AvroTimeMicroConsumer(TimeMicroVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.logical.AvroTimeMicroConsumer
-
Instantiate a AvroTimeMicroConsumer.
- AvroTimeMillisConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer which consume date time-millis values from avro decoder.
- AvroTimeMillisConsumer(TimeMilliVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.logical.AvroTimeMillisConsumer
-
Instantiate a AvroTimeMilliConsumer.
- AvroTimestampMicrosConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer which consume date timestamp-micro values from avro decoder.
- AvroTimestampMicrosConsumer(TimeStampMicroVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.logical.AvroTimestampMicrosConsumer
-
Instantiate a AvroTimestampMicroConsumer.
- AvroTimestampMillisConsumer - Class in org.apache.arrow.adapter.avro.consumers.logical
-
Consumer which consume date timestamp-millis values from avro decoder.
- AvroTimestampMillisConsumer(TimeStampMilliVector) - Constructor for class org.apache.arrow.adapter.avro.consumers.logical.AvroTimestampMillisConsumer
-
Instantiate a AvroTimestampMillisConsumer.
- AvroToArrow - Class in org.apache.arrow.adapter.avro
-
Utility class to convert Avro objects to columnar Arrow format objects.
- AvroToArrow() - Constructor for class org.apache.arrow.adapter.avro.AvroToArrow
- AvroToArrowConfig - Class in org.apache.arrow.adapter.avro
-
This class configures the Avro-to-Arrow conversion process.
- AvroToArrowConfigBuilder - Class in org.apache.arrow.adapter.avro
-
This class builds
AvroToArrowConfig
s. - AvroToArrowConfigBuilder(BufferAllocator) - Constructor for class org.apache.arrow.adapter.avro.AvroToArrowConfigBuilder
-
Default constructor for the
AvroToArrowConfigBuilder
. - avroToArrowIterator(Schema, Decoder, AvroToArrowConfig) - Static method in class org.apache.arrow.adapter.avro.AvroToArrow
-
Fetch the data from
Decoder
and iteratively convert it to Arrow objects. - AvroToArrowUtils - Class in org.apache.arrow.adapter.avro
-
Class that does most of the work to convert Avro data into Arrow columnar format Vector objects.
- AvroToArrowUtils() - Constructor for class org.apache.arrow.adapter.avro.AvroToArrowUtils
- AvroToArrowVectorIterator - Class in org.apache.arrow.adapter.avro
-
VectorSchemaRoot iterator for partially converting avro data.
- AvroUnionsConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Consumer which consume unions type values from avro decoder.
- AvroUnionsConsumer(UnionVector, Consumer[], Types.MinorType[]) - Constructor for class org.apache.arrow.adapter.avro.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.
- backpressureThreshold(int) - Method in class org.apache.arrow.flight.FlightServer.Builder
-
Set the number of bytes that may be queued on a server output stream before writes are blocked.
- BaseAvroConsumer<T extends FieldVector> - Class in org.apache.arrow.adapter.avro.consumers
-
Base class for non-skippable avro consumers.
- BaseAvroConsumer(T) - Constructor for class org.apache.arrow.adapter.avro.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.
- BaseLargeRepeatedValueViewVector - Class in org.apache.arrow.vector.complex
- BaseLargeRepeatedValueViewVector(String, BufferAllocator, FieldVector, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- BaseLargeRepeatedValueViewVector(String, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- 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.
- 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, FieldVector, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- BaseRepeatedValueVector(String, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- BaseRepeatedValueViewVector - Class in org.apache.arrow.vector.complex
- BaseRepeatedValueViewVector(String, BufferAllocator, FieldVector, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- BaseRepeatedValueViewVector(String, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.
- BaseVariableWidthViewVector - Class in org.apache.arrow.vector
-
BaseVariableWidthViewVector is a base class providing functionality for strings/bytes types in view format.
- BaseVariableWidthViewVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.BaseVariableWidthViewVector
-
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(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(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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- bigInt() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- bigInt(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- bigInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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
- BIGINT - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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(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 - Class in org.apache.arrow.flatbuf
-
Opaque binary data
- Binary - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Binary - Static variable in class org.apache.arrow.flatbuf.Type
- Binary() - Constructor for class org.apache.arrow.flatbuf.Binary
- Binary() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Binary
- Binary.Vector - Class in org.apache.arrow.flatbuf
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- BinaryView - Static variable in class org.apache.arrow.flatbuf.Type
- BinaryView() - Constructor for class org.apache.arrow.flatbuf.BinaryView
- BinaryView() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.BinaryView
- BinaryView.Vector - Class in org.apache.arrow.flatbuf
- 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(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
- bindAll() - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder.Builder
-
Bind each column to the corresponding parameter in order.
- bindService() - Method in class org.apache.arrow.flight.impl.FlightServiceGrpc.FlightServiceImplBase
- bindService(FlightServiceGrpc.AsyncService) - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
- bit() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- bit() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- bit() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- bit(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- bit(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- bit(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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
- BIT - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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(int) - Static method in class org.apache.arrow.vector.BitVectorHelper
-
Get the relative index of bit within the byte in validity buffer.
- bitIndex(long) - 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Bool - Static variable in class org.apache.arrow.flatbuf.Type
- Bool() - Constructor for class org.apache.arrow.flatbuf.Bool
- Bool() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Bool
- BOOL_VALUE - Enum constant in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- BOOL_VALUE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- Bool.Vector - Class in org.apache.arrow.flatbuf
- 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.
- BUF_INDEX_WIDTH - Static variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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.NullableViewVarBinaryHolder
- buffer - Variable in class org.apache.arrow.vector.holders.NullableViewVarCharHolder
- buffer - Variable in class org.apache.arrow.vector.holders.VarBinaryHolder
- buffer - Variable in class org.apache.arrow.vector.holders.VarCharHolder
- buffer - Variable in class org.apache.arrow.vector.holders.ViewVarBinaryHolder
- buffer - Variable in class org.apache.arrow.vector.holders.ViewVarCharHolder
- buffer(long) - Method in class org.apache.arrow.memory.RootAllocator
- 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 class org.apache.arrow.memory.RootAllocator
- buffer(long, BufferManager) - Method in interface org.apache.arrow.memory.BufferAllocator
-
Allocate a new or reused buffer of the provided size.
- 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 - 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.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
- BufferLedger.TransferResult - Class in org.apache.arrow.memory
-
The outcome of a Transfer.
- BufferManager - Interface in org.apache.arrow.memory
-
Manages a list of
ArrowBuf
s 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.avro.AvroToArrowConfigBuilder
-
This builds the
AvroToArrowConfig
from the provided params. - build() - Method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder.Builder
-
Build the binder.
- build() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
- 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.CloseSessionRequest.Builder
- build() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.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.GetSessionOptionsRequest.Builder
- build() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.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.SessionOptionValue.Builder
- build() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- build() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- build() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- build() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- build() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.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.CommandStatementIngest.Builder
- build() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.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.DoPutPreparedStatementResult.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.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(StructVector) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriterFactory
-
Creates a new instance.
- builder() - Static method in class org.apache.arrow.flight.FlightClient
-
Create a builder for a Flight client.
- builder() - Static method in class org.apache.arrow.flight.FlightServer
-
Create a builder for a Flight server.
- builder(PreparedStatement, VectorSchemaRoot) - Static method in class org.apache.arrow.adapter.jdbc.JdbcParameterBinder
-
Initialize a binder with a builder.
- builder(Ticket, Location...) - Static method in class org.apache.arrow.flight.FlightEndpoint
-
Create a builder for FlightEndpoint.
- builder(BufferAllocator, Location) - Static method in class org.apache.arrow.flight.FlightClient
-
Create a builder for a Flight client.
- builder(BufferAllocator, Location, FlightProducer) - Static method in class org.apache.arrow.flight.FlightServer
-
Create a builder for a Flight server.
- builder(Schema, FlightDescriptor, List<FlightEndpoint>) - Static method in class org.apache.arrow.flight.FlightInfo
-
Create a builder for FlightInfo.
- 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.CloseSessionRequest.Builder
- buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.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.GetSessionOptionsRequest.Builder
- buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.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.SessionOptionValue.Builder
- buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- buildPartial() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.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.CommandStatementIngest.Builder
- buildPartial() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.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.DoPutPreparedStatementResult.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
- 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(int) - Static method in class org.apache.arrow.vector.BitVectorHelper
-
Get the index of byte corresponding to bit index in validity buffer.
- byteIndex(long) - 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.adapter.avro.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 - Variable in class org.apache.arrow.vector.holders.FixedSizeBinaryHolder
- byteWidth - Variable in class org.apache.arrow.vector.holders.NullableFixedSizeBinaryHolder
- byteWidth() - Method in class org.apache.arrow.flatbuf.FixedSizeBinary
-
Number of bytes per value
C
- callBack - Variable in class org.apache.arrow.vector.complex.AbstractContainerVector
- callBack - Variable in class org.apache.arrow.vector.complex.LargeListVector
- callBack - Variable in class org.apache.arrow.vector.complex.RunEndEncodedVector
- 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 - Variable in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
- CallOptions - Class in org.apache.arrow.flight
-
Common call options.
- CallOptions() - Constructor for class org.apache.arrow.flight.CallOptions
- 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) - Constructor for class org.apache.arrow.flight.CallStatus
-
Create a new status with no cause or description.
- CallStatus(FlightStatusCode, Throwable, String, ErrorFlightMetadata) - Constructor for class org.apache.arrow.flight.CallStatus
-
Create a new status.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
-
Deprecated.The cancellation request is complete.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
-
Deprecated.The cancellation request is in progress.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
-
Deprecated.The query is not cancellable.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
-
Deprecated.The cancellation status is unknown.
- 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 - Enum constant in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
The cancellation request is complete.
- CANCEL_STATUS_CANCELLED_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
The cancellation request is complete.
- CANCEL_STATUS_CANCELLING - Enum constant in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
The cancellation request is in progress.
- 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 - Enum constant in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
The query is not cancellable.
- CANCEL_STATUS_NOT_CANCELLABLE_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
The query is not cancellable.
- CANCEL_STATUS_UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
The cancellation status is unknown.
- 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 - Enum constant in enum org.apache.arrow.flight.BackpressureStrategy.WaitResult
-
Listener was cancelled by the client.
- CANCELLED - Enum constant in enum org.apache.arrow.flight.CancelStatus
-
The cancellation request is complete.
- CANCELLED - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The operation was cancelled.
- CANCELLED - Enum constant in enum org.apache.arrow.flight.sql.CancelResult
-
Deprecated.
- CANCELLED - Static variable in class org.apache.arrow.flight.CallStatus
- CANCELLING - Enum constant in enum org.apache.arrow.flight.CancelStatus
-
The cancellation request is in progress.
- CANCELLING - Enum constant in enum org.apache.arrow.flight.sql.CancelResult
-
Deprecated.
- 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
- 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() - 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
CASCADE = 0;
- 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
- CATALOG_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- 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 ofexpectedStates
, 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, 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, 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) - 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) - 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) - 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, 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 sizesize
. - 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 sizesize
. - 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, 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, 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) - 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) - 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) - 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, 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.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 sizesize
. - 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 sizesize
. - checkPositionIndexes(int, int, int) - Static method in class org.apache.arrow.util.Preconditions
-
Ensures that
start
andend
specify a valid positions in an array, list or string of sizesize
, and are in order. - 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.
- 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.
- 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, 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, 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) - 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) - 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) - 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, 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.CloseSessionRequest.Builder
- clear() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.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.GetSessionOptionsRequest.Builder
- clear() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.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.SessionOptionValue.Builder
- clear() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- clear() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- clear() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- clear() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- clear() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.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.CommandStatementIngest.Builder
- clear() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.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.DoPutPreparedStatementResult.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
-
Same as
BaseFixedWidthVector.close()
. - clear() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
-
Same as
BaseLargeVariableWidthVector.close()
. - clear() - Method in class org.apache.arrow.vector.BaseValueVector
- clear() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
-
Same as
BaseVariableWidthVector.close()
. - clear() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Same as
BaseVariableWidthViewVector.close()
. - clear() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- clear() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- clear() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.Float2WriterImpl
- 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.PromotableViewWriter
- 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.UnionLargeListViewWriter
- clear() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- clear() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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.impl.ViewVarBinaryWriterImpl
- clear() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- clear() - Method in class org.apache.arrow.vector.complex.LargeListVector
- clear() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Clear the vector data.
- clear() - Method in class org.apache.arrow.vector.complex.ListVector
- clear() - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Clear the vector data.
- clear() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- clear() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Release any owned ArrowBuf and reset the ValueVector to the initial state.
- clear() - Method in class org.apache.arrow.vector.complex.StructVector
-
Same as
StructVector.close()
. - 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;
- clearBoolValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
bool bool_value = 2;
- 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.
- clearCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The catalog of the destination table to load data into.
- 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.
- clearDataBuffers() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Release the data buffers and clear the list.
- 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.
- clearDescription() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
-
string description = 2;
- clearDoubleValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
double double_value = 4;
- 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;
- clearErrors() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- 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;
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
-
Deprecated.
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- 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.
- clearIfExists() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- clearIfNotExist() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- 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.
- clearInt64Value() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
sfixed64 int64_value = 3;
- 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.
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
-
Deprecated.
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- clearOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- clearOptionValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- 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 aFlightSqlClient.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.
- clearPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
-
Represents a (potentially updated) 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.
- 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.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The db_schema of the destination table to load data into.
- clearSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- clearSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- 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;
- clearStatus() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- clearStringListValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- clearStringValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
string string_value = 1;
- 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.
- clearTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The table to load data into.
- clearTableDefinitionOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- 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.
- clearTemporary() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Store ingested data in a temporary table.
- 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.CommandStatementIngest.Builder
-
Perform the ingestion as part of this transaction.
- 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;
- clearValue() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- clearValues() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- clearVersion() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
-
The Substrait release, e.g.
- 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.flight.impl.Flight.Action.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- clone() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
-
Deprecated.
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
-
Deprecated.
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
- clone() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- 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 org.apache.arrow.adapter.avro.AvroToArrowVectorIterator
-
Clean up resources.
- close() - Method in class org.apache.arrow.adapter.avro.consumers.AvroArraysConsumer
- close() - Method in class org.apache.arrow.adapter.avro.consumers.AvroMapConsumer
- close() - Method in class org.apache.arrow.adapter.avro.consumers.AvroStructConsumer
- close() - Method in class org.apache.arrow.adapter.avro.consumers.AvroUnionsConsumer
- close() - Method in class org.apache.arrow.adapter.avro.consumers.BaseAvroConsumer
- close() - Method in class org.apache.arrow.adapter.avro.consumers.CompositeAvroConsumer
- close() - Method in interface org.apache.arrow.adapter.avro.consumers.Consumer
-
Close this consumer when occurs exception to avoid potential leak.
- close() - Method in class org.apache.arrow.adapter.avro.consumers.SkipConsumer
- 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.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.PutResult
- close() - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
- close() - Method in class org.apache.arrow.flight.sql.FlightSqlClient
- 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 class org.apache.arrow.memory.RootAllocator
- 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() - 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.BaseVariableWidthViewVector
-
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.Float2WriterImpl
- 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.PromotableViewWriter
- 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.UnionLargeListViewWriter
- close() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- close() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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.impl.ViewVarBinaryWriterImpl
- close() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- close() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- close() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Alternative to clear().
- 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() - 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
- close(boolean) - Method in class org.apache.arrow.vector.ipc.ArrowReader
-
Close resources, including vector schema root and dictionary vectors.
- 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(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(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
-
Closes the client.
- CLOSE_SESSION - Static variable in interface org.apache.arrow.flight.FlightConstants
- CLOSED - Enum constant in enum org.apache.arrow.flight.CloseSessionResult.Status
-
The session close request is complete.
- CLOSED - Enum constant in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
The session close request is complete.
- CLOSED_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
The session close request is complete.
- 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 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.
- closeSession() - Method in class org.apache.arrow.flight.ServerSessionMiddleware
-
Close the current session.
- closeSession(CloseSessionRequest, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Close/invalidate the current server session.
- closeSession(CloseSessionRequest, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
- closeSession(CloseSessionRequest, FlightProducer.CallContext, FlightProducer.StreamListener<CloseSessionResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Close/invalidate the session.
- CloseSessionRequest - Class in org.apache.arrow.flight
-
A request to close/invalidate a server session context.
- CloseSessionRequest() - Constructor for class org.apache.arrow.flight.CloseSessionRequest
- CloseSessionResult - Class in org.apache.arrow.flight
-
The result of attempting to close/invalidate a server session context.
- CloseSessionResult(CloseSessionResult.Status) - Constructor for class org.apache.arrow.flight.CloseSessionResult
- CloseSessionResult.Status - Enum in org.apache.arrow.flight
-
Close operation result status values.
- CloseSessionResultListener - Class in org.apache.arrow.flight.sql
-
Typed StreamListener for closeSession.
- CLOSING - Enum constant in enum org.apache.arrow.flight.CloseSessionResult.Status
-
The session close request is in progress.
- CLOSING - Enum constant in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
The session close request is in progress.
- CLOSING_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
The session close request is in progress.
- CMD - Enum constant in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
-
An opaque command to generate a dataset.
- 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() - Method in class org.apache.arrow.util.AutoCloseables.RollbackCloseable
- commit(FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Commit a transaction.
- 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(short, short) - Static method in class org.apache.arrow.memory.util.Float16
-
Compares the two specified half-precision float values.
- 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.
- 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.
- 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
- compareBaseVariableWidthViewVectors(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
- compareLargeListViewVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- compareListVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- compareListViewVectors(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.
- compareRunEndEncodedVectors(Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- 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) - Constructor for class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- ComplexWriterImpl(String, NonNullableStructVector, boolean) - Constructor for class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- ComplexWriterImpl(String, NonNullableStructVector, boolean, boolean) - Constructor for class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
-
Constructs a new instance.
- CompositeAvroConsumer - Class in org.apache.arrow.adapter.avro.consumers
-
Composite consumer which hold all consumers.
- CompositeAvroConsumer(List<Consumer>) - Constructor for class org.apache.arrow.adapter.avro.consumers.CompositeAvroConsumer
- 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
- configBuilder() - Static method in class org.apache.arrow.memory.RootAllocator
-
Returns a builder class for configuring BaseAllocator's options.
- CONFLICT_APPEND - Enum constant in enum org.apache.arrow.vector.complex.AbstractStructVector.ConflictPolicy
- CONFLICT_ERROR - Enum constant in enum org.apache.arrow.vector.complex.AbstractStructVector.ConflictPolicy
- CONFLICT_IGNORE - Enum constant in enum org.apache.arrow.vector.complex.AbstractStructVector.ConflictPolicy
- CONFLICT_REPLACE - Enum constant in enum org.apache.arrow.vector.complex.AbstractStructVector.ConflictPolicy
- 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.adapter.avro.consumers.AvroArraysConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroBooleanConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroBytesConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroDoubleConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroEnumConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroFixedConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroFloatConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroIntConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroLongConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroMapConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroNullConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroStringConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroStructConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.AvroUnionsConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.CompositeAvroConsumer
-
Consume decoder data.
- consume(Decoder) - Method in interface org.apache.arrow.adapter.avro.consumers.Consumer
-
Consume a specific type value from avro decoder and write it to vector.
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.logical.AvroDateConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.logical.AvroDecimalConsumer.BytesDecimalConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.logical.AvroDecimalConsumer.FixedDecimalConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.logical.AvroTimeMicroConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.logical.AvroTimeMillisConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.logical.AvroTimestampMicrosConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.logical.AvroTimestampMillisConsumer
- consume(Decoder) - Method in class org.apache.arrow.adapter.avro.consumers.SkipConsumer
- Consumer<T extends FieldVector> - Interface in org.apache.arrow.adapter.avro.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
- containsErrors(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- containsErrors(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- containsErrors(String) - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- containsKey(Object) - Method in class org.apache.arrow.vector.util.MapWithOrdinalImpl
- 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(K) - Method in class org.apache.arrow.vector.util.MultiMapWithOrdinal
- containsKey(K) - Method in class org.apache.arrow.vector.util.PromotableMultiMapWithOrdinal
- containsOptions(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Backend-specific options.
- containsOptions(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Backend-specific options.
- containsOptions(String) - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Backend-specific options.
- containsSessionOptions(String) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- containsSessionOptions(String) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- containsSessionOptions(String) - Method in interface org.apache.arrow.flight.impl.Flight.GetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- containsSessionOptions(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- containsSessionOptions(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- containsSessionOptions(String) - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequestOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- 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 theContext
. - 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 toout
. - 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.
- copy() - Method in class org.apache.arrow.vector.table.Table
-
Returns a deep copy of this table.
- 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
- copyAsField(String, BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, BaseWriter.MapWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- 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.Float2ReaderImpl
- 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, 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, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- copyAsField(String, BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- copyAsField(String, BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, BigIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
- copyAsField(String, BitWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, BitWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, BitWriter) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
- copyAsField(String, DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, DateDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
- copyAsField(String, DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, DateMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
- copyAsField(String, Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, Decimal256Writer) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
- copyAsField(String, DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, DecimalWriter) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
- copyAsField(String, DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, DurationWriter) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
- copyAsField(String, FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, FixedSizeBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
- copyAsField(String, Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, Float2Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float2Reader
- copyAsField(String, Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, Float4Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
- copyAsField(String, Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, Float8Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
- copyAsField(String, IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, IntervalDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
- copyAsField(String, IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, IntervalMonthDayNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
- copyAsField(String, IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, IntervalYearWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
- copyAsField(String, IntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, IntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, IntWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
- copyAsField(String, LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, LargeVarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
- copyAsField(String, LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, LargeVarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
- copyAsField(String, SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, SmallIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
- copyAsField(String, TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
- copyAsField(String, TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
- copyAsField(String, TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
- copyAsField(String, TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
- copyAsField(String, TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampMicroTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
- copyAsField(String, TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
- copyAsField(String, TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampMilliTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
- copyAsField(String, TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
- copyAsField(String, TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampNanoTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
- copyAsField(String, TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
- copyAsField(String, TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampSecTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
- copyAsField(String, TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, TimeStampSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
- copyAsField(String, TinyIntWriter) - 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, TinyIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
- copyAsField(String, UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, UInt1Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
- copyAsField(String, UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, UInt2Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
- copyAsField(String, UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, UInt4Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
- copyAsField(String, UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, UInt8Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
- copyAsField(String, VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, VarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
- copyAsField(String, VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, VarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
- copyAsField(String, ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, ViewVarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarBinaryReader
- copyAsField(String, ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsField(String, ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsField(String, ViewVarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarCharReader
- copyAsValue(DenseUnionWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(DenseUnionWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
- copyAsValue(UnionLargeListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListReader
- copyAsValue(UnionWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(UnionWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(UnionWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(UnionWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(UnionWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
- copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(BaseWriter.ListWriter) - 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.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListReader
- copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- copyAsValue(BaseWriter.ListWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(BaseWriter.ListWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedListReader
- copyAsValue(BaseWriter.MapWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(BaseWriter.MapWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedMapReader
- copyAsValue(BaseWriter.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- 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.StructWriter) - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
- copyAsValue(BaseWriter.StructWriter) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.RepeatedStructReader
- copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(BigIntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(BigIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
- copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(BitWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(BitWriter) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
- copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(DateDayWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(DateDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
- copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(DateMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(DateMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
- copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(Decimal256Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(Decimal256Writer) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
- copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(DecimalWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(DecimalWriter) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
- copyAsValue(DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(DurationWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(DurationWriter) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
- copyAsValue(FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(FixedSizeBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(FixedSizeBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
- copyAsValue(Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.Float2HolderReaderImpl
- copyAsValue(Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.Float2ReaderImpl
- copyAsValue(Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(Float2Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(Float2Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float2Reader
- copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(Float4Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(Float4Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
- copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(Float8Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(Float8Writer) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
- copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(IntervalDayWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(IntervalDayWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
- copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(IntervalMonthDayNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(IntervalMonthDayNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
- copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(IntervalYearWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(IntervalYearWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
- copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(IntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(IntWriter) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
- copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(LargeVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(LargeVarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
- copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(LargeVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(LargeVarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
- copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(SmallIntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(SmallIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
- copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
- copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
- copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
- copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeSecWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
- copyAsValue(TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampMicroTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampMicroTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
- copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampMicroWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampMicroWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
- copyAsValue(TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampMilliTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampMilliTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
- copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampMilliWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampMilliWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
- copyAsValue(TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampNanoTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampNanoTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
- copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampNanoWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampNanoWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
- copyAsValue(TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampSecTZWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampSecTZWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
- copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TimeStampSecWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TimeStampSecWriter) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
- copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(TinyIntWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(TinyIntWriter) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
- copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(UInt1Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(UInt1Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
- copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(UInt2Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(UInt2Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
- copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(UInt4Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(UInt4Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
- copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(UInt8Writer) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(UInt8Writer) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
- copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(VarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(VarBinaryWriter) - 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(VarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
- copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(VarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- 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(VarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
- copyAsValue(ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- copyAsValue(ViewVarBinaryWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- copyAsValue(ViewVarBinaryWriter) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarBinaryReader
- copyAsValue(ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- copyAsValue(ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- copyAsValue(ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- copyAsValue(ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- copyAsValue(ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- copyAsValue(ViewVarCharWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- copyAsValue(ViewVarCharWriter) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarCharReader
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- 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.ListViewVector
- 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.
- copyFromMemory(long, byte[], long, long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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.BaseVariableWidthViewVector
-
Same as
BaseVariableWidthViewVector.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.LargeListViewVector
- 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.ListViewVector
- 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. - copyMemory(long, long, long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- copyReader(FieldReader) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- copyReader(FieldReader) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- copyReaderToField(String, FieldReader) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.
- copyToMemory(byte[], long, long, long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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.Float2ReaderImpl
- 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
- copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- copyValue(FieldWriter) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- 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(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(ResultSet, JdbcToArrowConfig) - Static method in class org.apache.arrow.adapter.jdbc.ArrowVectorIterator
-
Create a ArrowVectorIterator to partially convert data.
- create(BufferAllocator, long) - Method in interface org.apache.arrow.memory.AllocationManager.Factory
-
Create an
AllocationManager
. - create(BufferAllocator, long) - Method in class org.apache.arrow.memory.unsafe.DefaultAllocationManagerFactory
- create(Schema, BufferAllocator) - Static method in class org.apache.arrow.vector.VectorSchemaRoot
-
Creates a new set of empty vectors corresponding to the given schema.
- create(Decoder, Schema, AvroToArrowConfig) - Static method in class org.apache.arrow.adapter.avro.AvroToArrowVectorIterator
-
Create a ArrowVectorIterator to partially convert data.
- 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
. - 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 theCompressionCodec
. - 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
- createCodec(CompressionUtil.CodecType) - 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) - Method in class org.apache.arrow.vector.compression.NoCompressionCodec.Factory
- createCodec(CompressionUtil.CodecType, int) - Method in class org.apache.arrow.compression.CommonsCompressionFactory
- 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, int) - Method in class org.apache.arrow.vector.compression.NoCompressionCodec.Factory
- createConsumer(BinaryConsumer, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BlobConsumer
-
Creates a consumer for
VarBinaryVector
. - createConsumer(BigIntVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BigIntConsumer
-
Creates a consumer for
BigIntVector
. - createConsumer(BitVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BitConsumer
-
Creates a consumer for
BitVector
. - createConsumer(ListVector, JdbcConsumer, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
-
Creates a consumer for
ListVector
. - createConsumer(MapVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.MapConsumer
-
Creates a consumer for
MapVector
. - 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(Float4Vector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.FloatConsumer
-
Creates a consumer for
Float4Vector
. - createConsumer(Float8Vector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.DoubleConsumer
-
Creates a consumer for
Float8Vector
. - createConsumer(IntVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.IntConsumer
-
Creates a consumer for
IntVector
. - 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(TimeStampMilliTZVector, int, boolean, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.consumer.TimestampTZConsumer
-
Creates a consumer for
TimeStampMilliTZVector
. - createConsumer(TimeStampMilliVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.TimestampConsumer
-
Creates a consumer for
TimeStampMilliVector
. - createConsumer(TinyIntVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.TinyIntConsumer
-
Creates a consumer for
TinyIntVector
. - createConsumer(VarBinaryVector, int, boolean) - Static method in class org.apache.arrow.adapter.jdbc.consumer.BinaryConsumer
-
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(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(int, int, Integer) - Static method in class org.apache.arrow.vector.types.pojo.ArrowType.Decimal
- createDecimal(FlatBufferBuilder, int, int, int) - Static method in class org.apache.arrow.flatbuf.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
- 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
- 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
- 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.
- 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
- 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 aResult
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 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
- createStridesVector(FlatBufferBuilder, long[]) - Static method in class org.apache.arrow.flatbuf.Tensor
- 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.avro.consumers.BaseAvroConsumer
- currentIndex - Variable in class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
- customMetadata(int) - Method in class org.apache.arrow.flatbuf.Field
-
User-defined metadata
- customMetadata(int) - Method in class org.apache.arrow.flatbuf.Footer
-
User-defined metadata
- customMetadata(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.Field
- customMetadata(KeyValue, int) - Method in class org.apache.arrow.flatbuf.Footer
- customMetadata(KeyValue, int) - Method in class org.apache.arrow.flatbuf.Message
- 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() - Method in class org.apache.arrow.flatbuf.Footer
- customMetadataVector() - 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.Field
- customMetadataVector(KeyValue.Vector) - Method in class org.apache.arrow.flatbuf.Footer
- customMetadataVector(KeyValue.Vector) - Method in class org.apache.arrow.flatbuf.Message
- customMetadataVector(KeyValue.Vector) - Method in class org.apache.arrow.flatbuf.Schema
D
- data - Variable in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- data - Variable in class org.apache.arrow.vector.complex.impl.UnionReader
- data - Variable in class org.apache.arrow.vector.complex.impl.UnionWriter
- data() - 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() - 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.SparseTensor
- data(Buffer) - Method in class org.apache.arrow.flatbuf.Tensor
- data(RecordBatch) - Method in class org.apache.arrow.flatbuf.DictionaryBatch
- DATA - Enum constant in enum org.apache.arrow.vector.BufferLayout.BufferType
- 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.BaseLargeRepeatedValueViewVector
- 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.BaseRepeatedValueViewVector
- 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.
- dataBuffers - Variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Date - Static variable in class org.apache.arrow.flatbuf.Type
- Date() - Constructor for class org.apache.arrow.flatbuf.Date
- Date(DateUnit) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Date
- Date.Vector - Class in org.apache.arrow.flatbuf
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- dateDay() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- dateDay(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- dateDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- dateDay(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- DATEDAY - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- dateMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- dateMilli(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- dateMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- dateMilli(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- DATEMILLI - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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
- 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 - Enum constant in enum org.apache.arrow.vector.types.DateUnit
-
Days since epoch.
- DAY - Static variable in class org.apache.arrow.flatbuf.DateUnit
- DAY_TIME - Enum constant in enum org.apache.arrow.vector.types.IntervalUnit
-
Values are stored as some number of days and some number of milliseconds within that day.
- 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
- DEBUG - Static variable in class org.apache.arrow.memory.RootAllocator
- DEBUG_ALLOCATOR - Static variable in class org.apache.arrow.memory.RootAllocator
- DEBUG_LOG_LENGTH - Static variable in class org.apache.arrow.memory.RootAllocator
- decimal() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- decimal() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- decimal() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- decimal() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- decimal(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- decimal(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- decimal(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- decimal(String, int, int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- Decimal - Class in org.apache.arrow.flatbuf
-
Exact decimal value represented as an integer value in two's complement.
- Decimal - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Decimal - Static variable in class org.apache.arrow.flatbuf.Type
- Decimal() - Constructor for class org.apache.arrow.flatbuf.Decimal
- 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 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- decimal256() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- decimal256() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- decimal256(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- decimal256(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- decimal256(String, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- decimal256(String, int, int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- DECIMAL256 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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
- 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(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.
- 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(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(ValueVector) - Method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
-
Decodes a vector with the dictionary in this encoder.
- 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.
- 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_BACKPRESSURE_THRESHOLD - Static variable in class org.apache.arrow.flight.FlightServer
-
The default number of bytes that can be queued on an output stream before blocking.
- DEFAULT_BATCH_SIZE - Static variable in class org.apache.arrow.adapter.avro.AvroToArrowVectorIterator
- DEFAULT_BODY_COMPRESSION - Static variable in class org.apache.arrow.vector.compression.NoCompressionCodec
- DEFAULT_CONFIG - Static variable in class org.apache.arrow.memory.RootAllocator
- DEFAULT_DATA_VECTOR - Static variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- 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.BaseRepeatedValueViewVector
- 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_RUN_END_VECTOR - Static variable in class org.apache.arrow.vector.complex.RunEndEncodedVector
- 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.
- DEFAULT_VALUE_VECTOR - Static variable in class org.apache.arrow.vector.complex.RunEndEncodedVector
- DefaultAllocationManagerFactory - Class in org.apache.arrow.memory.unsafe
-
The default Allocation Manager Factory for a module.
- DefaultAllocationManagerFactory() - Constructor for class org.apache.arrow.memory.unsafe.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.
- defaultConfig() - Static method in class org.apache.arrow.memory.RootAllocator
-
Returns a default
BaseAllocator.Config
instance. - defaultDataVectorName - Variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- defaultDataVectorName - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- defaultDataVectorName - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- defaultDataVectorName - Variable in class org.apache.arrow.vector.complex.LargeListVector
- DefaultRoundingPolicy - Class in org.apache.arrow.memory.rounding
-
The default rounding policy.
- 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
. - delegate - Variable in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
- Dense - Enum constant in enum org.apache.arrow.vector.types.UnionMode
-
Each child vector is of variable width.
- Dense - Static variable in class org.apache.arrow.flatbuf.UnionMode
- DenseArray - Static variable in class org.apache.arrow.flatbuf.DictionaryKind
- DENSEUNION - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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(byte[], BufferAllocator) - Static method in class org.apache.arrow.vector.util.SchemaUtility
-
Deserialize Arrow schema from byte array.
- 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.CloseSessionRequest
-
Parse the serialized form of this protocol message.
- deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.CloseSessionResult
-
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.GetSessionOptionsRequest
-
Parse the serialized form of this protocol message.
- deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.GetSessionOptionsResult
-
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.SetSessionOptionsRequest
-
Parse the serialized form of this protocol message.
- deserialize(ByteBuffer) - Static method in class org.apache.arrow.flight.SetSessionOptionsResult
-
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(ByteBuffer) - Static method in class org.apache.arrow.vector.types.pojo.Schema
-
Deprecated.
- deserialize(ArrowType, String) - Method in class org.apache.arrow.vector.extension.OpaqueType
- 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.
- 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(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.
- 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.
- deserializeSchema(Message) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
-
Deserializes an Arrow Schema object from a schema message.
- deserializeSchema(MessageMetadataResult) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
-
Deserializes an Arrow Schema object from a
MessageMetadataResult
. - deserializeSchema(ReadChannel) - Static method in class org.apache.arrow.vector.ipc.message.MessageSerializer
-
Deserializes an Arrow Schema read from the input channel.
- 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 - Variable in class org.apache.arrow.vector.ipc.ArrowReader
- dictionaries(int) - Method in class org.apache.arrow.flatbuf.Footer
- dictionaries(Block, int) - Method in class org.apache.arrow.flatbuf.Footer
- 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 - Static variable in class org.apache.arrow.flatbuf.MessageHeader
- DictionaryBatch() - Constructor for class org.apache.arrow.flatbuf.DictionaryBatch
- 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 - Class in org.apache.arrow.vector.dictionary
-
Encoder/decoder for Dictionary encoded
ValueVector
. - 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(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 - Class in org.apache.arrow.vector.types.pojo
-
A POJO representation of Arrow Dictionary metadata.
- DictionaryEncoding() - Constructor for class org.apache.arrow.flatbuf.DictionaryEncoding
- 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) - Constructor for class org.apache.arrow.vector.dictionary.DictionaryHashTable
- DictionaryHashTable(ValueVector, ArrowBufHasher) - 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 - Variable in class org.apache.arrow.vector.table.BaseTable
-
An optional DictionaryProvider.
- DictionaryProvider - Interface in org.apache.arrow.vector.dictionary
-
A manager for association of dictionary IDs to their corresponding
Dictionary
. - 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(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).
- DO_ACTION - Enum constant in enum org.apache.arrow.flight.FlightMethod
- DO_EXCHANGE - Enum constant in enum org.apache.arrow.flight.FlightMethod
- DO_GET - Enum constant in enum org.apache.arrow.flight.FlightMethod
- DO_PUT - Enum constant in enum org.apache.arrow.flight.FlightMethod
- 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(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.
- 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 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, 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.
- 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 providedProtocolMessageEnum
by comparingProtocolMessageEnum.getNumber()
with the respective bit index of thebitmask
. - 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.
- 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
-
This method is used to perform a bidirectional data exchange between a client and a server.
- 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 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, 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 - Enum constant in enum org.apache.arrow.vector.types.FloatingPointPrecision
-
64-bit (i.e.
- DOUBLE - Static variable in class org.apache.arrow.flatbuf.Precision
- DOUBLE_VALUE - Enum constant in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- DOUBLE_VALUE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- duration() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- duration() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- duration() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- duration() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- duration() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- duration() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- duration() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- duration() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- duration() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- duration(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- duration(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- duration(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- duration(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- duration(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- duration(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- duration(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- duration(String, TimeUnit) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- duration(String, TimeUnit) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- Duration - Class in org.apache.arrow.flatbuf
- Duration - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Duration - Static variable in class org.apache.arrow.flatbuf.Type
- Duration() - Constructor for class org.apache.arrow.flatbuf.Duration
- Duration(TimeUnit) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Duration
- DURATION - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- Duration.Vector - Class in org.apache.arrow.flatbuf
- 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.
- ELEMENT_SIZE - Static variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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() - 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.unsafe.DefaultAllocationManagerFactory
- 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.DenseUnionVector
- 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.LargeListViewVector
- empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.ListVector
- empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.ListViewVector
- empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.NonNullableStructVector
-
Construct a new empty instance which replaces an existing field with the new one in case of name conflict.
- empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.RunEndEncodedVector
- empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.StructVector
-
Construct a new empty instance which replaces an existing field with the new one in case of name conflict.
- empty(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.UnionVector
- empty(String, BufferAllocator, boolean) - Static method in class org.apache.arrow.vector.complex.MapVector
-
Construct an empty MapVector with no data.
- EMPTY_BYTE_ARRAY - Static variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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
-
Construct a new empty instance which preserve fields with identical names.
- emptyWithDuplicates(String, BufferAllocator) - Static method in class org.apache.arrow.vector.complex.StructVector
-
Construct a new empty instance which preserve fields with identical names.
- 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(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.
- 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(StructVector, Map<Integer, Long>) - Method in class org.apache.arrow.vector.dictionary.StructSubfieldEncoder
-
Dictionary encodes subfields for complex 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(ValueVector, Dictionary) - Static method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
-
Dictionary encodes a vector with a provided dictionary.
- encodeListSubField(BaseListVector) - Method in class org.apache.arrow.vector.dictionary.ListSubfieldEncoder
-
Dictionary encodes subfields for complex vector with a provided dictionary.
- 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.NullableViewVarBinaryHolder
- end - Variable in class org.apache.arrow.vector.holders.NullableViewVarCharHolder
- 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 - Variable in class org.apache.arrow.vector.holders.ViewVarBinaryHolder
- end - Variable in class org.apache.arrow.vector.holders.ViewVarCharHolder
- end() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- end() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- end() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- end() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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() - Method in class org.apache.arrow.vector.ipc.ArrowWriter
- END_SAVEPOINT_RELEASE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
-
Release the savepoint.
- END_SAVEPOINT_RELEASE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
-
Release the savepoint.
- END_SAVEPOINT_ROLLBACK - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
-
Roll back to a 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
-
END_SAVEPOINT_UNSPECIFIED = 0;
- END_SAVEPOINT_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
-
END_SAVEPOINT_UNSPECIFIED = 0;
- END_TRANSACTION_COMMIT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
-
Commit the transaction.
- END_TRANSACTION_COMMIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
-
Commit the transaction.
- END_TRANSACTION_ROLLBACK - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
-
Roll back 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
-
END_TRANSACTION_UNSPECIFIED = 0;
- 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.ComplexWriterImpl
- endEntry() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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() - 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
- Endianness - Class in org.apache.arrow.flatbuf
-
---------------------------------------------------------------------- Endianness of the platform producing the data
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- endList() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- endList() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- endList() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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
- endList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.List
- endListView() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- endListView() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- endListView() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- endListView() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- endListView() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- endListView() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- endListView() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- endListView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.ListView
- endMap() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- endMap() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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
- endMap(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Map
- 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 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 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, int) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
End the current value.
- endValue(int, int) - Method in class org.apache.arrow.vector.complex.ListVector
-
End the current value.
- endValue(int, int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
End the current value.
- endValue(int, long) - Method in class org.apache.arrow.vector.complex.LargeListVector
-
End the current value.
- 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.
- ensureRegistered() - Static method in class org.apache.arrow.vector.extension.OpaqueType
-
Register the extension type so it can be used globally.
- 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 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.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.CloseSessionRequest
- equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue
- equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- equals(Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- 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.PollInfo
- equals(Object) - Method in class org.apache.arrow.flight.SetSessionOptionsResult.Error
- 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.CommandStatementIngest
- equals(Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult
- 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.vector.BufferLayout
- 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.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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.ArrowType.Utf8View
- 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(ValueVector) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
-
Check type equals without passing IN param in VectorVisitor.
- equals(VectorSchemaRoot) - Method in class org.apache.arrow.vector.VectorSchemaRoot
-
Determine if two VectorSchemaRoots are exactly equal.
- eraseSessionOption(String) - Method in class org.apache.arrow.flight.ServerSessionMiddleware.Session
-
Idempotently remove name from this session.
- error(Throwable) - Method in interface org.apache.arrow.flight.OutboundStreamListener
-
Indicate an error to the client.
- Error(SetSessionOptionsResult.ErrorValue) - Constructor for class org.apache.arrow.flight.SetSessionOptionsResult.Error
- ERROR - Enum constant in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
The session option cannot be set.
- ERROR - Enum constant in enum org.apache.arrow.flight.SetSessionOptionsResult.ErrorValue
-
The session option cannot be set.
- ERROR_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
The session option cannot be set.
- 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
- ERRORS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- 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.
- executeApp(CommandLine) - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
-
Calls
FlightSqlClientDemoApp.createFlightSqlClient(String, int)
in order to create aFlightSqlClient
to be used in future calls, and then callsFlightSqlClientDemoApp.executeCommand(CommandLine)
to execute the command parsed at execution. - executeCommand(CommandLine) - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
-
Parses the "
command
" CLI argument and redirects to the appropriate method. - executeIngest(ArrowStreamReader, FlightSqlClient.ExecuteIngestOptions, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Execute a bulk ingest on the server.
- executeIngest(ArrowStreamReader, FlightSqlClient.ExecuteIngestOptions, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Execute a bulk ingest on the server.
- executeIngest(VectorSchemaRoot, FlightSqlClient.ExecuteIngestOptions, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Execute a bulk ingest on the server.
- executeIngest(VectorSchemaRoot, FlightSqlClient.ExecuteIngestOptions, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Execute a bulk ingest on the server.
- ExecuteIngestOptions(String, FlightSql.CommandStatementIngest.TableDefinitionOptions, boolean, String, String, Map<String, String>) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.ExecuteIngestOptions
-
Constructor.
- ExecuteIngestOptions(String, FlightSql.CommandStatementIngest.TableDefinitionOptions, String, String, Map<String, String>) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.ExecuteIngestOptions
-
Constructor.
- 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(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.
- 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
- exportBuffer(ArrowBuf, List<ArrowBuf>, ArrowBuf, long, boolean) - Method in interface org.apache.arrow.vector.FieldVector
-
Export a given buffer and its memory address into a list of buffers and a pointer to the list of buffers.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
-
Export the buffers of the fields for C Data Interface.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
-
Export the buffers of the fields for C Data Interface.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Get the data buffer of the vector.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in class org.apache.arrow.vector.complex.LargeListVector
-
Export the buffers of the fields for C Data Interface.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Export the buffers of the fields for C Data Interface.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in class org.apache.arrow.vector.complex.ListVector
-
Export the buffers of the fields for C Data Interface.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Export the buffers of the fields for C Data Interface.
- exportCDataBuffers(List<ArrowBuf>, ArrowBuf, long) - Method in interface org.apache.arrow.vector.FieldVector
-
Export the buffers of the fields for C Data Interface.
- 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.
- EXTENSION_NAME - Static variable in class org.apache.arrow.vector.extension.OpaqueType
- extensionEquals(ArrowType.ExtensionType) - Method in class org.apache.arrow.vector.extension.OpaqueType
- 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.extension.OpaqueType
- 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
- EXTENSIONTYPE - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - 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() - Constructor for class org.apache.arrow.vector.compression.NoCompressionCodec.Factory
- Factory(Callable<String>) - Constructor for class org.apache.arrow.flight.ServerSessionMiddleware.Factory
-
Construct a factory for ServerSessionMiddleware.
- Factory(CallHeaderAuthenticator) - Constructor for class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware.Factory
-
Construct a factory with the given auth handler.
- Factory(ClientHeaderHandler) - Constructor for class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware.Factory
-
Construct a factory with the given header handler.
- FACTORY - Static variable in class org.apache.arrow.memory.unsafe.DefaultAllocationManagerFactory
- FACTORY - Static variable in class org.apache.arrow.memory.unsafe.UnsafeAllocationManager
- FAILED_LOCAL - Enum constant in enum org.apache.arrow.memory.AllocationOutcome.Status
-
Allocation failed because the local allocator's limits were exceeded.
- FAILED_PARENT - Enum constant in enum org.apache.arrow.memory.AllocationOutcome.Status
-
Allocation failed because a parent allocator's limits were exceeded.
- 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
- 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 - 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.BaseVariableWidthViewVector
- field - Variable in class org.apache.arrow.vector.complex.LargeListViewVector
- field - Variable in class org.apache.arrow.vector.complex.ListVector
- field - Variable in class org.apache.arrow.vector.complex.ListViewVector
- field - Variable in class org.apache.arrow.vector.complex.NonNullableStructVector
- field - Variable in class org.apache.arrow.vector.complex.RunEndEncodedVector
- field - Variable in class org.apache.arrow.vector.NullVector
- 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 - Class in org.apache.arrow.vector.types.pojo
-
A POJO abstraction for the Flatbuffer description of Vector Type.
- Field() - Constructor for class org.apache.arrow.flatbuf.Field
- Field(String, FieldType, List<Field>) - Constructor for class org.apache.arrow.vector.types.pojo.Field
-
Constructs a new Field object.
- 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).
- fillEmpties(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Create holes in the vector upto the given index (exclusive).
- fillEmpties(int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
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) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
- finalizeHashCode(int, long) - Static method in class org.apache.arrow.memory.util.hash.MurmurHasher
-
Finalizing the hash code.
- 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 positionstart
. - findField(String) - Method in class org.apache.arrow.vector.types.pojo.Schema
-
Search for a field by name in this Schema.
- 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.
- 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
- FIXED_SIZE_LIST - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- FixedDecimalConsumer(DecimalVector, int) - Constructor for class org.apache.arrow.adapter.avro.consumers.logical.AvroDecimalConsumer.FixedDecimalConsumer
-
Instantiate a FixedDecimalConsumer.
- fixedListVector - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- fixedSizeBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- fixedSizeBinary() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- fixedSizeBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- fixedSizeBinary(String, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- fixedSizeBinary(String, int) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- FixedSizeBinary - Class in org.apache.arrow.flatbuf
- FixedSizeBinary - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- FixedSizeBinary - Static variable in class org.apache.arrow.flatbuf.Type
- FixedSizeBinary() - Constructor for class org.apache.arrow.flatbuf.FixedSizeBinary
- FixedSizeBinary(int) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeBinary
- FIXEDSIZEBINARY - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- FixedSizeBinary.Vector - Class in org.apache.arrow.flatbuf
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- FixedSizeList - Static variable in class org.apache.arrow.flatbuf.Type
- FixedSizeList() - Constructor for class org.apache.arrow.flatbuf.FixedSizeList
- FixedSizeList(int) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.FixedSizeList
- FixedSizeList.Vector - Class in org.apache.arrow.flatbuf
- 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_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 - Enum constant 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_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_BULK_INGESTION - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether the Flight SQL Server supports executing bulk ingestion.
- FLIGHT_SQL_SERVER_BULK_INGESTION_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 bulk ingestion.
- FLIGHT_SQL_SERVER_CANCEL - Enum constant 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_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_INGEST_TRANSACTIONS_SUPPORTED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether transactions are supported for bulk ingestion.
- FLIGHT_SQL_SERVER_INGEST_TRANSACTIONS_SUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether transactions are supported for bulk ingestion.
- FLIGHT_SQL_SERVER_NAME - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_SUBSTRAIT_MAX_VERSION - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_TRANSACTION_TIMEOUT - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string with the native version of the Flight SQL Server.
- 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.
- 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.CloseSessionRequest - Class in org.apache.arrow.flight.impl
-
Request message for the "Close Session" action.
- Flight.CloseSessionRequest.Builder - Class in org.apache.arrow.flight.impl
-
Request message for the "Close Session" action.
- Flight.CloseSessionRequestOrBuilder - Interface in org.apache.arrow.flight.impl
- Flight.CloseSessionResult - Class in org.apache.arrow.flight.impl
-
The result of closing a session.
- Flight.CloseSessionResult.Builder - Class in org.apache.arrow.flight.impl
-
The result of closing a session.
- Flight.CloseSessionResult.Status - Enum in org.apache.arrow.flight.impl
-
Protobuf enum
arrow.flight.protocol.CloseSessionResult.Status
- Flight.CloseSessionResultOrBuilder - Interface in org.apache.arrow.flight.impl
- 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.GetSessionOptionsRequest - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: A request to access the session options for the current server session.
- Flight.GetSessionOptionsRequest.Builder - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: A request to access the session options for the current server session.
- Flight.GetSessionOptionsRequestOrBuilder - Interface in org.apache.arrow.flight.impl
- Flight.GetSessionOptionsResult - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: The result containing the current server session options.
- Flight.GetSessionOptionsResult.Builder - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: The result containing the current server session options.
- Flight.GetSessionOptionsResultOrBuilder - 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.SessionOptionValue - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: Union of possible value types for a Session Option to be set to.
- Flight.SessionOptionValue.Builder - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: Union of possible value types for a Session Option to be set to.
- Flight.SessionOptionValue.OptionValueCase - Enum in org.apache.arrow.flight.impl
- Flight.SessionOptionValue.StringListValue - Class in org.apache.arrow.flight.impl
-
Protobuf type
arrow.flight.protocol.SessionOptionValue.StringListValue
- Flight.SessionOptionValue.StringListValue.Builder - Class in org.apache.arrow.flight.impl
-
Protobuf type
arrow.flight.protocol.SessionOptionValue.StringListValue
- Flight.SessionOptionValue.StringListValueOrBuilder - Interface in org.apache.arrow.flight.impl
- Flight.SessionOptionValueOrBuilder - Interface in org.apache.arrow.flight.impl
- Flight.SetSessionOptionsRequest - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: A request to set session options for an existing or new (implicit) server session.
- Flight.SetSessionOptionsRequest.Builder - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: A request to set session options for an existing or new (implicit) server session.
- Flight.SetSessionOptionsRequestOrBuilder - Interface in org.apache.arrow.flight.impl
- Flight.SetSessionOptionsResult - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: The results (individually) of setting a set of session options.
- Flight.SetSessionOptionsResult.Builder - Class in org.apache.arrow.flight.impl
-
EXPERIMENTAL: The results (individually) of setting a set of session options.
- Flight.SetSessionOptionsResult.Error - Class in org.apache.arrow.flight.impl
-
Protobuf type
arrow.flight.protocol.SetSessionOptionsResult.Error
- Flight.SetSessionOptionsResult.Error.Builder - Class in org.apache.arrow.flight.impl
-
Protobuf type
arrow.flight.protocol.SetSessionOptionsResult.Error
- Flight.SetSessionOptionsResult.ErrorOrBuilder - Interface in org.apache.arrow.flight.impl
- Flight.SetSessionOptionsResult.ErrorValue - Enum in org.apache.arrow.flight.impl
-
Protobuf enum
arrow.flight.protocol.SetSessionOptionsResult.ErrorValue
- Flight.SetSessionOptionsResultOrBuilder - 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
- 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, Instant, Location...) - Constructor for class org.apache.arrow.flight.FlightEndpoint
-
Constructs a new endpoint with an expiration time.
- FlightEndpoint(Ticket, Location...) - Constructor for class org.apache.arrow.flight.FlightEndpoint
-
Constructs a new endpoint with no expiration time.
- FlightEndpoint.Builder - Class in org.apache.arrow.flight
-
Builder for FlightEndpoint.
- 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, 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(Schema, FlightDescriptor, List<FlightEndpoint>, long, long, IpcOption) - 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.CommandStatementIngest - Class in org.apache.arrow.flight.sql.impl
-
Represents a bulk ingestion request.
- FlightSql.CommandStatementIngest.Builder - Class in org.apache.arrow.flight.sql.impl
-
Represents a bulk ingestion request.
- FlightSql.CommandStatementIngest.TableDefinitionOptions - Class in org.apache.arrow.flight.sql.impl
-
Options for table definition behavior
- FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder - Class in org.apache.arrow.flight.sql.impl
-
Options for table definition behavior
- FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption - Enum in org.apache.arrow.flight.sql.impl
-
The action to take if the target table already exists
- FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption - Enum in org.apache.arrow.flight.sql.impl
-
The action to take if the target table does not exist
- FlightSql.CommandStatementIngest.TableDefinitionOptionsOrBuilder - Interface in org.apache.arrow.flight.sql.impl
- FlightSql.CommandStatementIngestOrBuilder - 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.DoPutPreparedStatementResult - Class in org.apache.arrow.flight.sql.impl
-
An *optional* response returned when `DoPut` is called with `CommandPreparedStatementQuery`.
- FlightSql.DoPutPreparedStatementResult.Builder - Class in org.apache.arrow.flight.sql.impl
-
An *optional* response returned when `DoPut` is called with `CommandPreparedStatementQuery`.
- FlightSql.DoPutPreparedStatementResultOrBuilder - 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, or CommandStatementIngest 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, or CommandStatementIngest 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.ExecuteIngestOptions - Class in org.apache.arrow.flight.sql
-
Class to encapsulate Flight SQL bulk ingest request options.
- 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.
- 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
. - 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.
- Float16 - Class in org.apache.arrow.memory.util
-
Lifted from Apache Parquet MR project: https://github.com/apache/parquet-mr/blob/e87b80308869b77f914fcfd04364686e11158950/parquet-column/src/main/java/org/apache/parquet/schema/Float16.java Changes made: Modify the data type input from Parquet-MR Binary (toFloat(Binary b)) to Arrow Java short (toFloat(short b)) Expose NAN and POSITIVE_INFINITY variables The class is a utility class to manipulate half-precision 16-bit IEEE 754 floating point data types (also called fp16 or binary16).
- Float16() - Constructor for class org.apache.arrow.memory.util.Float16
- float2() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- float2() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- float2() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- float2() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- float2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- float2(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- FLOAT2 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- Float2Holder - Class in org.apache.arrow.vector.holders
-
Source code generated using FreeMarker template ValueHolders.java
- Float2Holder() - Constructor for class org.apache.arrow.vector.holders.Float2Holder
- Float2HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
- Float2HolderReaderImpl(Float2Holder) - Constructor for class org.apache.arrow.vector.complex.impl.Float2HolderReaderImpl
- Float2Reader - Interface in org.apache.arrow.vector.complex.reader
-
Source code generated using FreeMarker template ComplexReaders.java
- Float2ReaderImpl - Class in org.apache.arrow.vector.complex.impl
-
Source code generated using FreeMarker template ComplexReaders.java
- Float2ReaderImpl(Float2Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Float2ReaderImpl
- Float2Vector - Class in org.apache.arrow.vector
-
Float2Vector implements a fixed width (2 bytes) vector of short values which could be null.
- Float2Vector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float2Vector
-
Instantiate a Float2Vector.
- Float2Vector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float2Vector
-
Instantiate a Float2Vector.
- Float2Vector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.Float2Vector
-
Instantiate a Float2Vector.
- Float2Writer - Interface in org.apache.arrow.vector.complex.writer
- Float2WriterImpl - Class in org.apache.arrow.vector.complex.impl
- Float2WriterImpl(Float2Vector) - Constructor for class org.apache.arrow.vector.complex.impl.Float2WriterImpl
- float4() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- float4() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- float4() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- float4(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- float4(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- float4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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
- FLOAT4 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- float8() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- float8() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- float8(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- float8(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- float8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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
- FLOAT8 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- FloatingPoint - Static variable in class org.apache.arrow.flatbuf.Type
- FloatingPoint() - Constructor for class org.apache.arrow.flatbuf.FloatingPoint
- FloatingPoint(FloatingPointPrecision) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.FloatingPoint
- FloatingPoint.Vector - Class in org.apache.arrow.flatbuf
- 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 class org.apache.arrow.memory.RootAllocator
-
Increase the accounting.
- forceAllocate(long) - Method in interface org.apache.arrow.memory.BufferAllocator
-
Forcibly allocate bytes.
- FORCED_SUCCESS - Enum constant in enum org.apache.arrow.memory.AllocationOutcome.Status
-
Allocation succeeded but only because the allocator was forced to move beyond a limit.
- 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
- 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.CloseSessionResult.Status
- forNumber(int) - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
- forNumber(int) - Static method in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- forNumber(int) - Static method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
- 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.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
- forNumber(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
- 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.
- freeMemory(long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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
. - fromProtocol(Flight.CloseSessionResult.Status) - Static method in enum org.apache.arrow.flight.CloseSessionResult.Status
- fromThrowable(Throwable) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
-
Convert arbitrary exceptions to a
FlightRuntimeException
.
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
withvalueCount
random values. - get(int) - Method in class org.apache.arrow.flatbuf.Binary.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.BinaryView.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Block.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.BodyCompression.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Bool.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Buffer.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Date.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Decimal.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.DictionaryBatch.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Duration.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Field.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.FieldNode.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.FixedSizeList.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.FloatingPoint.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Footer.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Int.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Interval.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.KeyValue.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.LargeBinary.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.LargeList.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.LargeListView.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.LargeUtf8.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.List.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.ListView.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Map.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Message.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Null.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.RecordBatch.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.RunEndEncoded.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Schema.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.SparseTensor.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Struct_.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Tensor.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.TensorDim.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Time.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Timestamp.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Union.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Utf8.Vector
- get(int) - Method in class org.apache.arrow.flatbuf.Utf8View.Vector
- get(int) - Method in class org.apache.arrow.vector.BigIntVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.BitVector
-
Get the element at the given index from the vector.
- get(int) - 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) - Method in class org.apache.arrow.vector.DateMilliVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.Decimal256Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.DecimalVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.DurationVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.Float2Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.Float4Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.Float8Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.IntervalDayVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.IntervalYearVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.IntVector
-
Get the element at the given index from 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) - Method in class org.apache.arrow.vector.LargeVarCharVector
-
Get the variable length element at specified index as byte array.
- get(int) - Method in class org.apache.arrow.vector.SmallIntVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.TimeMicroVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.TimeMilliVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.TimeNanoVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.TimeSecVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.TimeStampVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.TinyIntVector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.UInt1Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.UInt2Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.UInt4Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.UInt8Vector
-
Get the element at the given index from the vector.
- get(int) - Method in class org.apache.arrow.vector.VarBinaryVector
-
Get the variable length element at specified index as byte array.
- get(int) - Method in class org.apache.arrow.vector.VarCharVector
-
Get the variable length element at specified index as byte array.
- get(int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Get the variable length element at the specified index.
- get(int) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Get the variable length element at specified index as a byte array.
- get(int) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Get the variable length element at specified index as a byte array.
- 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, ComplexHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- get(int, DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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(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(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(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(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, 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(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, 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(int, NullableFloat2Holder) - Method in class org.apache.arrow.vector.Float2Vector
-
Get the element at the given index from the vector and sets the state in holder.
- 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(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(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, 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, 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, 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(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, 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, 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(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(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(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(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(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, 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, 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, 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, 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, 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, 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, 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, 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(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(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, 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, 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(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, 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(int, NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Get the variable length element at specified index and sets the state in provided holder.
- get(int, NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Get the variable length element at specified index and sets the state in provided holder.
- get(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(TemporalUnit) - Method in class org.apache.arrow.vector.PeriodDuration
- get(K) - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
-
Returns the value of the mapping with the specified key.
- 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(Binary, int) - Method in class org.apache.arrow.flatbuf.Binary.Vector
- get(BinaryView, int) - Method in class org.apache.arrow.flatbuf.BinaryView.Vector
- get(Block, int) - Method in class org.apache.arrow.flatbuf.Block.Vector
- get(BodyCompression, int) - Method in class org.apache.arrow.flatbuf.BodyCompression.Vector
- get(Bool, int) - Method in class org.apache.arrow.flatbuf.Bool.Vector
- get(Buffer, int) - Method in class org.apache.arrow.flatbuf.Buffer.Vector
- get(Date, int) - Method in class org.apache.arrow.flatbuf.Date.Vector
- get(Decimal, int) - Method in class org.apache.arrow.flatbuf.Decimal.Vector
- get(DictionaryBatch, int) - Method in class org.apache.arrow.flatbuf.DictionaryBatch.Vector
- get(DictionaryEncoding, int) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding.Vector
- get(Duration, int) - Method in class org.apache.arrow.flatbuf.Duration.Vector
- get(FieldNode, int) - Method in class org.apache.arrow.flatbuf.FieldNode.Vector
- get(Field, int) - Method in class org.apache.arrow.flatbuf.Field.Vector
- get(FixedSizeBinary, int) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary.Vector
- get(FixedSizeList, int) - Method in class org.apache.arrow.flatbuf.FixedSizeList.Vector
- get(FloatingPoint, int) - Method in class org.apache.arrow.flatbuf.FloatingPoint.Vector
- get(Footer, int) - Method in class org.apache.arrow.flatbuf.Footer.Vector
- get(Interval, int) - Method in class org.apache.arrow.flatbuf.Interval.Vector
- get(Int, int) - Method in class org.apache.arrow.flatbuf.Int.Vector
- get(KeyValue, int) - Method in class org.apache.arrow.flatbuf.KeyValue.Vector
- get(LargeBinary, int) - Method in class org.apache.arrow.flatbuf.LargeBinary.Vector
- get(LargeList, int) - Method in class org.apache.arrow.flatbuf.LargeList.Vector
- get(LargeListView, int) - Method in class org.apache.arrow.flatbuf.LargeListView.Vector
- get(LargeUtf8, int) - Method in class org.apache.arrow.flatbuf.LargeUtf8.Vector
- get(List, int) - Method in class org.apache.arrow.flatbuf.List.Vector
- get(ListView, int) - Method in class org.apache.arrow.flatbuf.ListView.Vector
- get(Map, int) - Method in class org.apache.arrow.flatbuf.Map.Vector
- get(Message, int) - Method in class org.apache.arrow.flatbuf.Message.Vector
- get(Null, int) - Method in class org.apache.arrow.flatbuf.Null.Vector
- get(RecordBatch, int) - Method in class org.apache.arrow.flatbuf.RecordBatch.Vector
- get(RunEndEncoded, int) - Method in class org.apache.arrow.flatbuf.RunEndEncoded.Vector
- get(Schema, int) - Method in class org.apache.arrow.flatbuf.Schema.Vector
- get(SparseMatrixIndexCSX, int) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX.Vector
- get(SparseTensorIndexCOO, int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO.Vector
- get(SparseTensorIndexCSF, int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF.Vector
- get(SparseTensor, int) - Method in class org.apache.arrow.flatbuf.SparseTensor.Vector
- get(Struct_, int) - Method in class org.apache.arrow.flatbuf.Struct_.Vector
- get(TensorDim, int) - Method in class org.apache.arrow.flatbuf.TensorDim.Vector
- get(Tensor, int) - Method in class org.apache.arrow.flatbuf.Tensor.Vector
- get(Time, int) - Method in class org.apache.arrow.flatbuf.Time.Vector
- get(Timestamp, int) - Method in class org.apache.arrow.flatbuf.Timestamp.Vector
- get(Union, int) - Method in class org.apache.arrow.flatbuf.Union.Vector
- get(Utf8, int) - Method in class org.apache.arrow.flatbuf.Utf8.Vector
- get(Utf8View, int) - Method in class org.apache.arrow.flatbuf.Utf8View.Vector
- 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(ArrowBuf, int) - Static method in class org.apache.arrow.vector.BitVectorHelper
-
Check if a bit at a given index is set or not.
- 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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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_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_FLIGHT_INFO - Enum constant in enum org.apache.arrow.flight.FlightMethod
- 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_SCHEMA - Enum constant in enum org.apache.arrow.flight.FlightMethod
- GET_SCHEMAS_SCHEMA - Static variable in class org.apache.arrow.flight.sql.FlightSqlProducer.Schemas
- GET_SESSION_OPTIONS - Static variable in interface org.apache.arrow.flight.FlightConstants
- 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
- 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 class org.apache.arrow.memory.RootAllocator
-
Return the current amount of allocated memory that this Accountant is managing accounting for.
- 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.avro.AvroToArrowConfig
- getAllocator() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
-
The Arrow memory allocator.
- 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.RunEndEncodedVector
- 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.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;
- 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. - 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. - 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
- 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(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(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.
- 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(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.
- getBigIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getBigIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getBigIntVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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() - Method in class org.apache.arrow.vector.complex.UnionVector
- getBitVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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
- 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
- getBoolValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
bool bool_value = 2;
- getBoolValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
bool bool_value = 2;
- getBoolValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
bool bool_value = 2;
- 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() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
-
Get the record batch buffers.
- 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.BaseVariableWidthViewVector
-
Return the underlying buffers associated with this vector.
- getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.AbstractStructVector
-
Return the underlying buffers associated with this vector.
- getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
-
Return the underlying buffers associated with this vector.
- getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
-
Return the underlying buffers associated with this vector.
- 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.LargeListViewVector
-
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.ListViewVector
-
Return the underlying buffers associated with this vector.
- getBuffers(boolean) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
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(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.BaseVariableWidthViewVector
-
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.BaseLargeRepeatedValueViewVector
- getBufferSize() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- getBufferSize() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.LargeListViewVector
-
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.ListViewVector
-
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.RunEndEncodedVector
-
Get the number of bytes used by this vector.
- 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.BaseVariableWidthViewVector
-
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.BaseLargeRepeatedValueViewVector
- getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.LargeListViewVector
-
Get the size (number of bytes) of underlying buffers used by this.
- getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.ListVector
- getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Get the size (number of bytes) of underlying buffers used by this.
- getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getBufferSizeFor(int) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Returns the number of bytes that is used by this vector if it holds the given number of values.
- 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(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.
- getByte(long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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
- 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 class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Get the size (number of bytes) of underlying view 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() - Method in class org.apache.arrow.flight.FlightInfo
- getBytes() - Method in class org.apache.arrow.flight.Ticket
- getBytes() - Method in class org.apache.arrow.vector.util.Text
-
Returns the raw bytes; however, only data up to
ReusableByteArray.getLength()
is valid. - 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, 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(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.
- 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
- getCallHeaders() - Method in class org.apache.arrow.flight.ServerSessionMiddleware
- getCallOptions() - Method in class org.apache.arrow.flight.sql.example.FlightSqlClientDemoApp
-
Gets the current
CallOption
as an array; usually used as an argument inFlightSqlClient
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.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.impl.FlightSql.CommandStatementIngest.Builder
-
The catalog of the destination table to load data into.
- getCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The catalog of the destination table to load data into.
- getCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The catalog of the destination table to load data into.
- 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.
- getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The catalog of the destination table to load data into.
- getCatalogBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The catalog of the destination table to load data into.
- getCatalogBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The catalog of the destination table to load data into.
- getCatalogName() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
-
Returns the catalog name.
- 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. - 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.
- 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 class org.apache.arrow.memory.RootAllocator
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.ListVector
- getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getChildrenFromFields() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
The returned list is the same size as the list passed to initializeChildrenFromFields.
- 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
- 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.
- getCommand() - Method in class org.apache.arrow.flight.FlightDescriptor
- getConflictPolicy() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
- 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.adapter.avro.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(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
-
Get the schema of
FlightSqlClient.getCrossReference(TableRef, TableRef, CallOption...)
from the server. - getCurrentPosition() - Method in class org.apache.arrow.vector.ipc.WriteChannel
- getCustomMetadata() - Method in class org.apache.arrow.vector.types.pojo.Schema
- getData(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Retrieves the data of a variable-width element at a given index in the vector.
- getData(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- getDataBuffer() - Method in class org.apache.arrow.vector.complex.ListVector
- getDataBuffer() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getDataBuffer() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getDataBuffer() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Gets the underlying buffer associated with data vector.
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.ListVector
- getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getDataBufferAddress() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Gets the starting address of the underlying buffer associated with data vector.
- 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
- getDataBuffers() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Get the buffers that store the data for views in the vector.
- 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) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- getDataPointer(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
- getDataPointer(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- getDataPointer(int) - 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 class org.apache.arrow.vector.BaseFixedWidthVector
- getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
- getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- getDataPointer(int, ArrowBufPointer) - Method in class org.apache.arrow.vector.BitVector
- getDataPointer(int, ArrowBufPointer) - Method in interface org.apache.arrow.vector.ElementAddressableVector
-
Gets the pointer for the data at the given index.
- 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.vector.complex.BaseLargeRepeatedValueViewVector
- getDataVector() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- getDataVector() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.LargeListViewVector
- getDataVector() - Method in class org.apache.arrow.vector.complex.ListVector
-
Get the inner data vector for this list vector.
- getDataVector() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getDataVector() - Method in interface org.apache.arrow.vector.complex.RepeatedValueVector
-
Get the data vector.
- 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(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.
- 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(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.
- getDateDayVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getDateDayVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getDateDayVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getDateMilliVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getDateMilliVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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) - Method in class org.apache.arrow.vector.table.Row
-
Returns an ArrowBuf from the column with the given index at the current row.
- 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) - Method in class org.apache.arrow.vector.table.Row
-
Returns an ArrowBuf from the column of the given name 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.
- getDecimal256Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getDecimal256Vector(byte, ArrowType) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getDecimal256Vector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getDecimal256Vector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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.
- 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.
- getDecimalVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getDecimalVector(byte, ArrowType) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getDecimalVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getDecimalVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getDefaultAllocationManagerType() - Static method in class org.apache.arrow.memory.DefaultAllocationManagerOption
-
Returns the default allocation manager type.
- 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.CloseSessionRequest
- getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue
- getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- getDefaultInstance() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- 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.CommandStatementIngest
- getDefaultInstance() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult
- 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.CloseSessionRequest.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- 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.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.CommandStatementIngest.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult.Builder
- getDefaultInstanceForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- 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
- 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.
- 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.
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
-
Get the density of this LargeListViewVector.
- getDensity() - Method in class org.apache.arrow.vector.complex.ListVector
-
Get the density of this ListVector.
- getDensity() - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Get the density of this ListVector.
- getDescription() - Method in class org.apache.arrow.flight.ActionType
- 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.CloseSessionRequest.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- getDescriptor() - Static method in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
- 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.GetSessionOptionsRequest.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- getDescriptor() - Static method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
- getDescriptor() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- 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.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.CommandStatementIngest.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
- getDescriptor() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
- 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.DoPutPreparedStatementResult.Builder
- getDescriptor() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- 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
- 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.CloseSessionRequest.Builder
- getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- getDescriptorForType() - Method in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
- 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.GetSessionOptionsRequest.Builder
- getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.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.SessionOptionValue.Builder
- getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- getDescriptorForType() - Method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
- getDescriptorForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket.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.CommandStatementIngest.Builder
- getDescriptorForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
- getDescriptorForType() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
- 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.DoPutPreparedStatementResult.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.
- 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(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.
- getDoubleValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
double double_value = 4;
- getDoubleValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
double double_value = 4;
- getDoubleValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
double double_value = 4;
- getDuration() - Method in class org.apache.arrow.vector.PeriodDuration
- 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(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.
- 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(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.
- 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.
- 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.
- getDurationVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getDurationVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getDurationVector(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
- getElementEndIndex(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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
- getElementStartIndex(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
- getEmpty() - Method in class org.apache.arrow.memory.RootAllocator
- 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
- 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() - 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;
- 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.
- getEndpointBuilder() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
-
.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.
- 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() - 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;
- 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.
- 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
- getErrors() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
Deprecated.
- getErrors() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
-
Deprecated.
- getErrors() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResultOrBuilder
-
Deprecated.
- getErrors() - Method in class org.apache.arrow.flight.SetSessionOptionsResult
-
Get the error status map from the result object.
- getErrorsCount() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- getErrorsCount() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- getErrorsCount() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsMap() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsMap() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsMap() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsOrDefault(String, Flight.SetSessionOptionsResult.Error) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsOrDefault(String, Flight.SetSessionOptionsResult.Error) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsOrDefault(String, Flight.SetSessionOptionsResult.Error) - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsOrThrow(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsOrThrow(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getErrorsOrThrow(String) - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- getExecuteSchema(String, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Get the schema of the result set of a query.
- getExecuteSchema(String, FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Get the schema of the result set of a query.
- getExecuteSubstraitSchema(FlightSqlClient.SubstraitPlan, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Get the schema of the result set of a Substrait plan.
- 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.
- 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. - getExportedCDataBufferCount() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Retrieves the export buffer count for the C Data Interface.
- getExportedCDataBufferCount() - Method in interface org.apache.arrow.vector.FieldVector
-
Retrieves the export buffer count for the C Data Interface.
- 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
-
Get the schema of
FlightSqlClient.getExportedKeys(TableRef, CallOption...)
from the server. - 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.
- 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.BaseVariableWidthViewVector
-
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.UnionFixedSizeListReader
- 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.Float2ReaderImpl
- getField() - Method in class org.apache.arrow.vector.complex.impl.Float2WriterImpl
- 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.PromotableViewWriter
- 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.UnionLargeListViewReader
- getField() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- 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.UnionListViewReader
- getField() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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.impl.ViewVarBinaryReaderImpl
- getField() - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- getField() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- getField() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- getField() - Method in class org.apache.arrow.vector.complex.LargeListVector
- getField() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Get the field associated with the list view vector.
- getField() - Method in class org.apache.arrow.vector.complex.ListVector
- getField() - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Get the field associated with the list view vector.
- 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.RunEndEncodedVector
-
Get information about how this field is materialized.
- 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.extension.OpaqueVector
- getField() - Method in class org.apache.arrow.vector.ExtensionTypeVector
- getField() - Method in class org.apache.arrow.vector.NullVector
- getField() - Method in interface org.apache.arrow.vector.ValueVector
-
Get information about how this field is materialized.
- 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(String) - Method in class org.apache.arrow.vector.table.BaseTable
-
Returns the Field with the given name if one exists in this table.
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- 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.ListViewVector
- getFieldBuffers() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Get the buffers of the fields, (same size as getFieldVectors() since it is their content).
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
-
Deprecated.
- 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.ListViewVector
-
Deprecated.
- getFieldInnerVectors() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
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(int) - Method in class org.apache.arrow.vector.table.Row
-
Returns a byte[] from the column with the given index at the current row.
- 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.
- getFixedSizeBinaryVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getFixedSizeBinaryVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getFixedSizeBinaryVector(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() - 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.FlightProducer
-
Get information about a particular data stream.
- getFlightInfo(FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.NoOpFlightProducer
- getFlightInfo(FlightProducer.CallContext, FlightDescriptor) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Depending on the provided command, method either: 1.
- 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 interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
-
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.
- 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 inResult
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.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 inResult
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.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 inResult
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.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 inResult
objects. - getFlightInfoImportedKeys(FlightSql.CommandGetImportedKeys, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
- 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.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 inResult
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.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 inResult
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.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 aResult
. - getFlightInfoSqlInfo(FlightSql.CommandGetSqlInfo, FlightProducer.CallContext, FlightDescriptor) - Method in class org.apache.arrow.flight.sql.NoOpFlightSqlProducer
- 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 interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Evaluate a Substrait plan.
- 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 inResult
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.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 inResult
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.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(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.
- getFloat2Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getFloat2Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getFloat2Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getFloat4Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getFloat4Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getFloat4Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getFloat8Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getFloat8Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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
- getHeadroom() - Method in class org.apache.arrow.memory.RootAllocator
- 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.
- getHolderForUtf8(String, ArrowBuf) - Static method in class org.apache.arrow.flight.sql.SqlInfoBuilder
- 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
- getIfExists() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- getIfExists() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- getIfExists() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptionsOrBuilder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- getIfExistsValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- getIfExistsValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- getIfExistsValue() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptionsOrBuilder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- getIfNotExist() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- getIfNotExist() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- getIfNotExist() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptionsOrBuilder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- getIfNotExistValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- getIfNotExistValue() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- getIfNotExistValue() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptionsOrBuilder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- 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
-
Get the schema of
FlightSqlClient.getImportedKeys(TableRef, CallOption...)
from the server. - 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() - Method in class org.apache.arrow.vector.types.pojo.DictionaryEncoding
- getIndexType(int) - Static method in class org.apache.arrow.vector.dictionary.DictionaryEncoder
-
Get the indexType according to the dictionary vector valueCount.
- getInfo() - Method in class org.apache.arrow.flight.CancelFlightInfoRequest
- 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.
- getInfo(FlightDescriptor, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Get info on a stream.
- 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 class org.apache.arrow.memory.RootAllocator
-
Return the initial reservation.
- 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(byte[], int) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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(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(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(long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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(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(Field) - Static method in class org.apache.arrow.vector.types.pojo.ArrowType
- getInt64Value() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
sfixed64 int64_value = 3;
- getInt64Value() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
sfixed64 int64_value = 3;
- getInt64Value() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
sfixed64 int64_value = 3;
- 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(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.
- 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(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.
- 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() - Method in class org.apache.arrow.vector.complex.UnionVector
- getIntervalDayVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getIntervalDayVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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.
- 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.
- getIntervalMonthDayNanoVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getIntervalMonthDayNanoVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getIntervalMonthDayNanoVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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.
- 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.
- getIntervalYearVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getIntervalYearVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getIntervalYearVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- getIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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.
- 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(int) - Method in class org.apache.arrow.vector.table.Row
-
Returns a byte[] from the column with the given index at the current row.
- 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.
- getLargeVarBinaryVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getLargeVarBinaryVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getLargeVarBinaryVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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.
- 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.
- 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.
- 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.
- getLargeVarCharVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getLargeVarCharVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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.BaseVariableWidthViewVector
-
Get the index of the 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
- getLastSet() - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Get the index of the last non-null element in the vector.
- 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.RootAllocator
-
Return the current limit of this Accountant.
- 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() - Method in class org.apache.arrow.vector.complex.UnionVector
- getList(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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.
- 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.
- getListActionsMethod() - Static method in class org.apache.arrow.flight.impl.FlightServiceGrpc
- getListener() - Method in class org.apache.arrow.memory.RootAllocator
- 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
- getListView() - Method in class org.apache.arrow.vector.complex.UnionVector
- getListViewWriter() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- getListWriter() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- getLocalDateTimeFromEpochMicro(long) - Static method in class org.apache.arrow.vector.util.DateUtility
-
Convert microseconds from epoch to a LocalDateTime with UTC offset.
- getLocalDateTimeFromEpochMicro(long, String) - Static method in class org.apache.arrow.vector.util.DateUtility
-
Convert microseconds 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.
- getLocalDateTimeFromEpochMilli(long, String) - Static method in class org.apache.arrow.vector.util.DateUtility
-
Convert milliseconds 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.
- getLocalDateTimeFromEpochNano(long, String) - Static method in class org.apache.arrow.vector.util.DateUtility
-
Convert nanoseconds from epoch to a LocalDateTime with timeZone 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
- getLong(byte[], int) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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.
- getLong(long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- getLongHashCode(long) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
- 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() - Method in class org.apache.arrow.vector.complex.UnionVector
- getMap(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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.
- getMap(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getMap(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getMaxViewEndChildVector() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
-
Get the end of the child vector via the maximum view length.
- getMaxViewEndChildVector() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
-
Get the end of the child vector via the maximum view length.
- getMaxViewEndChildVectorByIndex(int) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
-
Get the end of the child vector via the maximum view length of the child vector by index.
- getMaxViewEndChildVectorByIndex(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
-
Get the end of the child vector via the maximum view length of the child vector by index.
- 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
- getMetadata() - Method in class org.apache.arrow.vector.types.pojo.Field
- getMetadata() - Method in class org.apache.arrow.vector.types.pojo.FieldType
- getMetaData() - Method in class org.apache.arrow.vector.ipc.ArrowFileReader
-
Get custom metadata.
- getMetaData() - Method in class org.apache.arrow.vector.ipc.message.ArrowFooter
- 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() - Method in interface org.apache.arrow.flight.FlightProducer.CallContext
-
Get an immutable map of middleware for this call.
- getMiddleware(FlightServerMiddleware.Key<T>) - Method in interface org.apache.arrow.flight.FlightProducer.CallContext
-
Get the middleware instance of the given type 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.Float2HolderReaderImpl
- getMinorType() - Method in class org.apache.arrow.vector.complex.impl.Float2ReaderImpl
- 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.NullableFloat2HolderReaderImpl
- 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.NullableViewVarBinaryHolderReaderImpl
- getMinorType() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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.UnionLargeListViewReader
- getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- getMinorType() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewReader
- 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.impl.ViewVarBinaryHolderReaderImpl
- getMinorType() - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- getMinorType() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- getMinorType() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- getMinorType() - Method in class org.apache.arrow.vector.complex.LargeListVector
- getMinorType() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Get the minor type for the vector.
- getMinorType() - Method in class org.apache.arrow.vector.complex.ListVector
- getMinorType() - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Get the minor type for the vector.
- 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.RunEndEncodedVector
- 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.Float2Vector
-
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.
- getMinorType() - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Get a minor type for this vector.
- getMinorType() - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Get a 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.
- getMutableErrors() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
Deprecated.
- getMutableOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Deprecated.
- getMutableSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
Deprecated.
- getMutableSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
Deprecated.
- 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 class org.apache.arrow.memory.RootAllocator
- 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 class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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.BaseLargeRepeatedValueViewVector
- getName() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- getName() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.RunEndEncodedVector
-
Gets the name of the vector.
- 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.
- getNewFieldWriter(ValueVector) - Method in enum org.apache.arrow.vector.types.Types.MinorType
- getNewVector(String, FieldType, BufferAllocator) - Method in class org.apache.arrow.vector.extension.OpaqueType
- 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.
- 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() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Get the number of elements that are null in the vector.
- 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.LargeListViewVector
-
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.ListViewVector
-
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.RunEndEncodedVector
-
Returns number of null elements in the vector.
- 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
- 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.
- getNumber() - Method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
- getNumber() - Method in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
- getNumber() - Method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
- getNumber() - Method in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- getNumber() - Method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
- 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.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
- getNumber() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
- 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
- getObject(int) - Method in class org.apache.arrow.vector.BigIntVector
-
Same as
BigIntVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.BitVector
-
Same as
BitVector.get(int)
. - 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.LargeListViewVector
-
Get the element in the list view 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.ListViewVector
-
Get the element in the list view 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.RunEndEncodedVector
-
Get friendly type object from the vector.
- 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
-
Same as
DateDayVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.DateMilliVector
-
Same as
DateMilliVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.Decimal256Vector
-
Same as
Decimal256Vector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.DecimalVector
-
Same as
DecimalVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.DurationVector
-
Same as
DurationVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.extension.OpaqueVector
- 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
-
Same as
FixedSizeBinaryVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.Float2Vector
-
Same as
Float2Vector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.Float4Vector
-
Same as
Float4Vector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.Float8Vector
-
Same as
Float8Vector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.IntervalDayVector
-
Same as
IntervalDayVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
-
Same as
IntervalMonthDayNanoVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.IntervalYearVector
-
Same as
IntervalYearVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.IntVector
-
Same as
IntVector.get(int)
. - 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
-
Same as
SmallIntVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeMicroVector
-
Same as
TimeMicroVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeMilliVector
-
Same as
TimeMilliVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeNanoVector
-
Same as
TimeNanoVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeSecVector
-
Same as
TimeSecVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampMicroTZVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampMicroVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampMilliTZVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampMilliVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampNanoTZVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampNanoVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampSecTZVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TimeStampSecVector
-
Same as
TimeStampVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.TinyIntVector
-
Same as
TinyIntVector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.UInt1Vector
-
Same as
UInt1Vector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.UInt2Vector
-
Same as
UInt2Vector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.UInt4Vector
-
Same as
UInt4Vector.get(int)
. - getObject(int) - Method in class org.apache.arrow.vector.UInt8Vector
-
Same as
UInt8Vector.get(int)
. - 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.
- getObject(int) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Get the variable length element at a specified index as a byte array.
- getObject(int) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Get the variable length element at specified index as Text.
- 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
-
Same as
UInt4Vector.get(int)
. - 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() - Method in class org.apache.arrow.vector.ipc.message.ArrowBlock
- getOffset() - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
- getOffset(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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.BaseVariableWidthViewVector
-
BaseVariableWidthViewVector doesn't support offset buffer.
- 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.LargeListViewVector
- getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.ListVector
- getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getOffsetBuffer() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Gets the underlying buffer associated with offset vector.
- 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.BaseVariableWidthViewVector
-
BaseVariableWidthViewVector doesn't support offset buffer.
- 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.LargeListViewVector
- getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.ListVector
- getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getOffsetBufferAddress() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Gets the starting address of the underlying buffer associated with offset vector.
- 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.BaseLargeRepeatedValueViewVector
- getOffsetBufferValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- getOffsetBufferValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- getOffsetBufferValueCapacity() - Method in class org.apache.arrow.vector.complex.LargeListVector
- getOffsetVector() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
-
Deprecated.
- 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.BaseRepeatedValueViewVector
-
Deprecated.
- 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.
- getOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Deprecated.
- getOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Deprecated.
- getOptions() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Deprecated.
- getOptionsCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- getOptionsCount() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- getOptionsCount() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Backend-specific options.
- getOptionsMap() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Backend-specific options.
- getOptionsMap() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Backend-specific options.
- getOptionsMap() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Backend-specific options.
- getOptionsOrDefault(String, String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Backend-specific options.
- getOptionsOrDefault(String, String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Backend-specific options.
- getOptionsOrDefault(String, String) - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Backend-specific options.
- getOptionsOrThrow(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Backend-specific options.
- getOptionsOrThrow(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Backend-specific options.
- getOptionsOrThrow(String) - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Backend-specific options.
- getOptionValueCase() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- getOptionValueCase() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- getOptionValueCase() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
- 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
- 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 class org.apache.arrow.memory.RootAllocator
- getParentAllocator() - Method in interface org.apache.arrow.memory.BufferAllocator
-
Returns the parent allocator.
- 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.CloseSessionRequest
- getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue
- getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- getParserForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
- 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.CommandStatementIngest
- getParserForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult
- 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.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 class org.apache.arrow.memory.RootAllocator
-
The peak memory allocated by this Accountant.
- 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
- getPhysicalIndex(int) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
The physical index is the index of the first value that is larger than logical index.
- 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
- getPort() - Method in class org.apache.arrow.flight.FlightServer
-
Get the port the server is running on (if applicable).
- getPosition() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- getPosition() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- 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
andTypes.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.
- getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
-
Represents a (potentially updated) opaque handle for the prepared statement on the server.
- getPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
-
Represents a (potentially updated) opaque handle for the prepared statement on the server.
- getPreparedStatementHandle() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResultOrBuilder
-
Represents a (potentially updated) opaque handle for the prepared statement on the server.
- 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
-
Get the schema of
FlightSqlClient.getPrimaryKeys(TableRef, CallOption...)
from the server. - getPrimitiveVectors() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
-
Get primitive child vectors.
- 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.
- 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.adapter.avro.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(InputStream) - Static method in class org.apache.arrow.flight.grpc.GetReadableBuffer
-
Extracts the ReadableBuffer for the given input stream.
- 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
- 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.LargeListViewVector
- getReader() - Method in class org.apache.arrow.vector.complex.ListVector
- getReader() - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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.RunEndEncodedVector
-
Get a reader for this vector.
- 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() - Method in interface org.apache.arrow.vector.ValueVector
-
Get a reader for this vector.
- getReader(int) - Method in class org.apache.arrow.vector.table.BaseTable
-
Returns a FieldReader for the field at the given vector index.
- 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.
- 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.LargeListViewVector
- getReaderImpl() - Method in class org.apache.arrow.vector.complex.ListVector
- getReaderImpl() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getReaderImpl() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
- 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.Float2Vector
- 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
- getReaderImpl() - Method in class org.apache.arrow.vector.ViewVarBinaryVector
- getReaderImpl() - Method in class org.apache.arrow.vector.ViewVarCharVector
- 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
- 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
- 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 class org.apache.arrow.memory.RootAllocator
- 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 class org.apache.arrow.memory.RootAllocator
- 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.
- getRunEnd(int) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Get the run end of giving index.
- getRunEndsVector() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
- 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
andTypes.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.flight.FlightInfo
-
Deprecated.Deprecated. Use
FlightInfo.getSchemaOptional()
instead. - 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() - Method in class org.apache.arrow.flight.SchemaResult
- getSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The db_schema of the destination table to load data into.
- getSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The db_schema of the destination table to load data into.
- getSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The db_schema of the destination table to load data into.
- 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() - Method in class org.apache.arrow.vector.VectorSchemaRoot
- 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(FlightDescriptor, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Get schema for a stream.
- 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.FlightProducer
-
Get schema for a particular data 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(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 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, 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.
- getSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The db_schema of the destination table to load data into.
- getSchemaBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The db_schema of the destination table to load data into.
- getSchemaBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The db_schema of the destination table to load data into.
- 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 interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Get the schema of the result set of a prepared statement.
- 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
-
Get the schema of
FlightSqlClient.getSchemas(String, String, CallOption...)
from the server. - 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 interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Get the result schema for a Substrait plan.
- getSegmentSize() - Method in class org.apache.arrow.memory.rounding.SegmentRoundingPolicy
-
Deprecated, for removal: This API element is subject to removal in a future version.
- getSegmentSizeAsLong() - 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.CloseSessionRequest
- getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue
- getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- getSerializedSize() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
- 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.CommandStatementIngest
- getSerializedSize() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult
- 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
- getSession() - Method in class org.apache.arrow.flight.ServerSessionMiddleware
-
Get the existing or new session value map for this call.
- getSessionOption(String) - Method in class org.apache.arrow.flight.ServerSessionMiddleware.Session
-
Get session option by name, or null if it does not exist.
- getSessionOptions() - Method in class org.apache.arrow.flight.GetSessionOptionsResult
-
Get the session options map contained in the request.
- getSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
Deprecated.
- getSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
-
Deprecated.
- getSessionOptions() - Method in interface org.apache.arrow.flight.impl.Flight.GetSessionOptionsResultOrBuilder
-
Deprecated.
- getSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
Deprecated.
- getSessionOptions() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
-
Deprecated.
- getSessionOptions() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequestOrBuilder
-
Deprecated.
- getSessionOptions() - Method in class org.apache.arrow.flight.ServerSessionMiddleware.Session
-
Get an immutable copy of the session options map.
- getSessionOptions() - Method in class org.apache.arrow.flight.SetSessionOptionsRequest
-
Get the session option map from the request.
- getSessionOptions(GetSessionOptionsRequest, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Get the current server session options.
- getSessionOptions(GetSessionOptionsRequest, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
- getSessionOptions(GetSessionOptionsRequest, FlightProducer.CallContext, FlightProducer.StreamListener<GetSessionOptionsResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Get server session option(s).
- getSessionOptionsCount() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- getSessionOptionsCount() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- getSessionOptionsCount() - Method in interface org.apache.arrow.flight.impl.Flight.GetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsCount() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- getSessionOptionsCount() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- getSessionOptionsCount() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequestOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsMap() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsMap() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsMap() - Method in interface org.apache.arrow.flight.impl.Flight.GetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsMap() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsMap() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsMap() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequestOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrDefault(String, Flight.SessionOptionValue) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrDefault(String, Flight.SessionOptionValue) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrDefault(String, Flight.SessionOptionValue) - Method in interface org.apache.arrow.flight.impl.Flight.GetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrDefault(String, Flight.SessionOptionValue) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrDefault(String, Flight.SessionOptionValue) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrDefault(String, Flight.SessionOptionValue) - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequestOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrThrow(String) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrThrow(String) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrThrow(String) - Method in interface org.apache.arrow.flight.impl.Flight.GetSessionOptionsResultOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrThrow(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrThrow(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- getSessionOptionsOrThrow(String) - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequestOrBuilder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- GetSessionOptionsRequest - Class in org.apache.arrow.flight
-
A request to get current session options.
- GetSessionOptionsRequest() - Constructor for class org.apache.arrow.flight.GetSessionOptionsRequest
- GetSessionOptionsResult - Class in org.apache.arrow.flight
-
A request to view the currently-set options for the current server session.
- GetSessionOptionsResult(Map<String, SessionOptionValue>) - Constructor for class org.apache.arrow.flight.GetSessionOptionsResult
- GetSessionOptionsResultListener - Class in org.apache.arrow.flight.sql
-
Typed StreamListener for getSessionOptions.
- 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.
- getShort(long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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 interface org.apache.arrow.memory.ReferenceManager
-
Total size (in bytes) of memory underlying this reference manager.
- getSize() - Method in class org.apache.arrow.memory.unsafe.UnsafeAllocationManager
- getSize() - Method in class org.apache.arrow.vector.ipc.message.ArrowBuffer
- getSizeBuffer() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- getSizeBuffer() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getSizeBufferAddress() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- getSizeBufferAddress() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getSizeBufferValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- getSizeBufferValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- getSizeLong() - Method in interface org.apache.arrow.memory.AllocationReservation
-
Get the current size of the reservation (the sum of all the add()s) as a long value.
- getSkipFieldNames() - Method in class org.apache.arrow.adapter.avro.AvroToArrowConfig
- 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(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.
- 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(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.
- getSmallIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getSmallIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getSmallIntVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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.
- 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.
- getSqlInfoSchema(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Get the schema of
FlightSqlClient.getSqlInfo(SqlInfo...)
from the server. - 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.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.CloseSessionResult
- 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.flight.impl.Flight.CloseSessionResult.Builder
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- getStatus() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- getStatus() - Method in interface org.apache.arrow.flight.impl.Flight.CloseSessionResultOrBuilder
-
.arrow.flight.protocol.CloseSessionResult.Status 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;
- getStatusValue() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- getStatusValue() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- getStatusValue() - Method in interface org.apache.arrow.flight.impl.Flight.CloseSessionResultOrBuilder
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- 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.NoOpFlightProducer
- getStream(FlightProducer.CallContext, Ticket, FlightProducer.ServerStreamListener) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Depending on the provided command, method either: 1.
- getStream(Ticket, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Retrieve a stream from the server.
- getStream(Ticket, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Retrieve a stream from the server.
- 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
- 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 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 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 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 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
- 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 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 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 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 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 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
- getStringListValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- getStringListValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- getStringListValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- getStringListValueBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- getStringListValueOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- getStringListValueOrBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- getStringListValueOrBuilder() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- getStringValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
string string_value = 1;
- getStringValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
string string_value = 1;
- getStringValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
string string_value = 1;
- getStringValueBytes() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
string string_value = 1;
- getStringValueBytes() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
string string_value = 1;
- getStringValueBytes() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
string string_value = 1;
- getStruct() - Method in class org.apache.arrow.vector.complex.UnionVector
- getStruct(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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.
- 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.impl.FlightSql.CommandStatementIngest.Builder
-
The table to load data into.
- getTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The table to load data into.
- getTable() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The table to load data into.
- 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.
- getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The table to load data into.
- getTableBytes() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The table to load data into.
- getTableBytes() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The table to load data into.
- getTableDefinitionOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- getTableDefinitionOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The behavior for handling the table definition.
- getTableDefinitionOptions() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The behavior for handling the table definition.
- getTableDefinitionOptionsBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- getTableDefinitionOptionsOrBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- getTableDefinitionOptionsOrBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The behavior for handling the table definition.
- getTableDefinitionOptionsOrBuilder() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The behavior for handling the table definition.
- 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, 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
-
Get the schema of
FlightSqlClient.getTables(String, String, String, List, boolean, CallOption...)
from the server. - 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.
- getTableTypes(CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Request a list of table types.
- 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.avro.AvroToArrowConfig
- getTargetBatchSize() - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
-
Get the target batch size for partial read.
- getTemporary() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Store ingested data in a temporary table.
- getTemporary() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Store ingested data in a temporary table.
- getTemporary() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Store ingested data in a temporary table.
- 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.
- getTimeFormatter() - Static method in class org.apache.arrow.vector.util.DateUtility
-
Returns time formatter used to parse time strings.
- 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(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.
- 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(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.
- getTimeMicroVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeMicroVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeMicroVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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.
- 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.
- getTimeMilliVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeMilliVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeMilliVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getTimeNanoVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeNanoVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeNanoVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getTimeSecVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeSecVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeSecVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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.
- 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.
- 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(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.
- 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(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.
- getTimeStampMicroTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMicroTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMicroTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMicroVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMicroVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeStampMicroVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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.
- 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.
- 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(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.
- 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(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.
- getTimeStampMilliTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMilliTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMilliTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMilliVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampMilliVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeStampMilliVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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.
- 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.
- 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(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.
- 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(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.
- getTimeStampNanoTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampNanoTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampNanoTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampNanoVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampNanoVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeStampNanoVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- 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.
- 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.
- 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(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.
- 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(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.
- getTimeStampSecTZVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampSecTZVector(String, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampSecTZVector(ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampSecVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimeStampSecVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTimeStampSecVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTimezone() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
- 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.
- 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(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.
- 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(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.
- getTinyIntVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getTinyIntVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTinyIntVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- getTotalValueLengthUpToIndex(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Get the total length of the elements up to the given index.
- 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.CommandStatementIngest.Builder
-
Perform the ingestion as part of this transaction.
- getTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Perform the ingestion as part of this transaction.
- getTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Perform the ingestion as part of this transaction.
- 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).
- 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(String, 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.BaseVariableWidthVector
-
Construct a transfer pair of this vector and another vector of same type.
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Construct a transfer pair of this vector and another vector of the 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(String, BufferAllocator) - Method in class org.apache.arrow.vector.BitVector
-
Construct a TransferPair comprising this and a target vector of the same type.
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.LargeListVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.ListVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.ListViewVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.MapVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
To transfer quota responsibility.
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.complex.StructVector
- getTransferPair(String, BufferAllocator) - 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(String, 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(String, 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(String, 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(String, BufferAllocator) - Method in class org.apache.arrow.vector.Float2Vector
-
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(String, 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(String, BufferAllocator) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
-
Construct a TransferPair comprising 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(String, 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(String, BufferAllocator) - Method in class org.apache.arrow.vector.LargeVarCharVector
-
Construct a TransferPair comprising this and a target vector of the same type.
- getTransferPair(String, BufferAllocator) - 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(String, 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(String, 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(String, 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(String, 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(String, 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(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(String, 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(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt1Vector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt2Vector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt4Vector
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.UInt8Vector
- getTransferPair(String, BufferAllocator) - 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(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(String, BufferAllocator) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Construct a TransferPair comprising this and a target vector of the same type.
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Construct a TransferPair comprising this and a target vector of the same type.
- getTransferPair(String, BufferAllocator) - Method in class org.apache.arrow.vector.ZeroVector
- 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(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(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(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Construct a transfer pair of this vector and another vector of the same type.
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.LargeListVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.ListVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.ListViewVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.MapVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
To transfer quota responsibility.
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.StructVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.ExtensionTypeVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.NullVector
- getTransferPair(String, BufferAllocator, CallBack) - Method in interface org.apache.arrow.vector.ValueVector
-
To transfer quota responsibility.
- getTransferPair(String, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.ZeroVector
- getTransferPair(BufferAllocator) - 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.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(BufferAllocator) - 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.BaseVariableWidthViewVector
-
Construct a transfer pair of this vector and another vector of the same type.
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
To transfer quota responsibility.
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.StructVector
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.ExtensionTypeVector
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.NullVector
- getTransferPair(BufferAllocator) - Method in interface org.apache.arrow.vector.ValueVector
-
To transfer quota responsibility.
- getTransferPair(BufferAllocator) - Method in class org.apache.arrow.vector.ZeroVector
- 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(Field, 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.BaseVariableWidthVector
-
Construct a transfer pair of this vector and another vector of same type.
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Construct a transfer pair of this vector and another 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(Field, 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.complex.DenseUnionVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.LargeListVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.ListVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.ListViewVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.MapVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
To transfer quota responsibility.
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.StructVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(Field, 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.Decimal256Vector
-
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(Field, BufferAllocator) - Method in class org.apache.arrow.vector.DurationVector
-
Construct a TransferPair comprising this and a target vector of the same type.
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.ExtensionTypeVector
- 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(Field, BufferAllocator) - Method in class org.apache.arrow.vector.Float2Vector
-
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(Field, 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.IntervalDayVector
-
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(Field, 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.IntVector
-
Construct a TransferPair comprising this and a target vector of the same type.
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.LargeVarBinaryVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.LargeVarCharVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.NullVector
- 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(Field, 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.TimeMilliVector
-
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(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(Field, 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.TimeStampMicroVector
-
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(Field, 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.TimeStampNanoTZVector
-
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(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(Field, 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.TinyIntVector
-
Construct a TransferPair comprising this and a target vector of the same type.
- 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(Field, BufferAllocator) - Method in class org.apache.arrow.vector.UInt2Vector
-
Construct a TransferPair comprising this and a target vector of the same type.
- 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(Field, BufferAllocator) - Method in class org.apache.arrow.vector.UInt8Vector
-
Construct a TransferPair comprising this and a target vector of the same type.
- getTransferPair(Field, BufferAllocator) - Method in interface org.apache.arrow.vector.ValueVector
-
To transfer quota responsibility.
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.VarBinaryVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.VarCharVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
- getTransferPair(Field, BufferAllocator) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Construct a TransferPair with a desired target vector of the 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(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(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(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Construct a transfer pair of this vector and another vector of the same type.
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.LargeListVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.ListVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.ListViewVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.MapVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
To transfer quota responsibility.
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.StructVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.complex.UnionVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.ExtensionTypeVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in class org.apache.arrow.vector.NullVector
- getTransferPair(Field, BufferAllocator, CallBack) - Method in interface org.apache.arrow.vector.ValueVector
-
To transfer quota responsibility.
- 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
- 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() - 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. - 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.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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(FlatBufferBuilder) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8View
- 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
BufferLayout
s for the givenarrowType
. - 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() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- getTypeId(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Binary
- getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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
- getTypeID() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8View
- 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
TypeLayout
for the givenarrowType
. - 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(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(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.
- 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(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.
- getUInt1Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getUInt1Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getUInt1Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getUInt2Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getUInt2Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getUInt2Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getUInt4Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getUInt4Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getUInt4Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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(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.
- 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(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.
- getUInt8Vector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getUInt8Vector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getUInt8Vector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- getUnderlyingVector() - Method in class org.apache.arrow.vector.ExtensionTypeVector
-
Get the underlying vector.
- 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
- getUnits() - Method in class org.apache.arrow.vector.PeriodDuration
- 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;
- getUsed() - Method in class org.apache.arrow.memory.AllocationOutcomeDetails.Entry
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- getValidityBuffer() - Method in class org.apache.arrow.vector.complex.ListVector
- getValidityBuffer() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getValidityBuffer() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getValidityBuffer() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Gets the underlying buffer associated with validity vector.
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.ListVector
- getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getValidityBufferAddress() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Gets the starting address of the underlying buffer associated with validity vector.
- 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
- getValue() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- getValue() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- getValue() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorOrBuilder
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- getValueAsDouble(int) - Method in class org.apache.arrow.vector.Float2Vector
- 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.
- getValueAsFloat(int) - Method in class org.apache.arrow.vector.Float2Vector
- 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.BaseVariableWidthViewVector
-
Get the current capacity which does not exceed either validity buffer or value buffer.
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.Float2WriterImpl
- 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.PromotableViewWriter
- 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.UnionLargeListViewWriter
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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.impl.ViewVarBinaryWriterImpl
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- 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.LargeListViewVector
-
Get the value capacity by considering validity and offset capacity.
- 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.ListViewVector
-
Get the value capacity by considering validity and offset capacity.
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getValueCapacity() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Returns the maximum number of values that can be stored in this vector instance.
- 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.BaseVariableWidthViewVector
-
Get the value count of vector.
- getValueCount() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- getValueCount() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- getValueCount() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.LargeListViewVector
- getValueCount() - Method in class org.apache.arrow.vector.complex.ListViewVector
- getValueCount() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- getValueCount() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Gets the number of values.
- 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.CloseSessionResult.Status
- getValueDescriptor() - Method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
- getValueDescriptor() - Method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
- 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.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
- getValueDescriptor() - Method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
- 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.
- getValueIterable() - Method in interface org.apache.arrow.vector.ValueIterableVector
-
Get an Iterator for the values in the vector.
- getValueIterator() - Method in interface org.apache.arrow.vector.ValueIterableVector
-
Get an Iterable that can be used to iterate over the values in the vector.
- 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.
- getValueLength(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Get the length of the element at specified index.
- getValueLength(int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Get the variable length element at specified index as Text.
- getValues(int) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- getValues(int) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
-
repeated string values = 1;
- getValues(int) - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValueOrBuilder
-
repeated string values = 1;
- getValuesBytes(int) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- getValuesBytes(int) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
-
repeated string values = 1;
- getValuesBytes(int) - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValueOrBuilder
-
repeated string values = 1;
- getValuesCount() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- getValuesCount() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
-
repeated string values = 1;
- getValuesCount() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValueOrBuilder
-
repeated string values = 1;
- getValuesList() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- getValuesList() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
-
repeated string values = 1;
- getValuesList() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValueOrBuilder
-
repeated string values = 1;
- getValuesVector() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
- getValueValue() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- getValueValue() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- getValueValue() - Method in interface org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorOrBuilder
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- getValueWidth() - Method in class org.apache.arrow.algorithm.sort.VectorValueComparator
- 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.
- 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.
- getVarBinaryVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getVarBinaryVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getVarBinaryVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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.
- 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.
- 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.
- 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.
- getVarCharVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getVarCharVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getVarCharVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- getVariadicBufferCounts() - Method in class org.apache.arrow.vector.ipc.message.ArrowRecordBatch
-
Get the record batch variadic buffer counts.
- getVector() - Method in class org.apache.arrow.adapter.avro.consumers.BaseAvroConsumer
- getVector() - Method in interface org.apache.arrow.adapter.avro.consumers.Consumer
-
Get the vector within the consumer.
- getVector() - Method in class org.apache.arrow.adapter.avro.consumers.SkipConsumer
- 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.vector.AddOrGetResult
-
Returns the vector.
- getVector() - Method in class org.apache.arrow.vector.dictionary.Dictionary
- getVector(int) - Method in class org.apache.arrow.vector.complex.UnionVector
- getVector(int) - Method in class org.apache.arrow.vector.VectorSchemaRoot
- getVector(int, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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
- 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
- getVectorCopy(int) - Method in class org.apache.arrow.vector.table.BaseTable
-
Returns a copy of the vector at the given position.
- 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.
- 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.
- getViewVarBinaryVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getViewVarBinaryVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getViewVarBinaryVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- getViewVarCharVector() - Method in class org.apache.arrow.vector.complex.UnionVector
- getViewVarCharVector(byte) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- getViewVarCharVector(String) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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() - 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.LargeListViewVector
- getWriter() - Method in class org.apache.arrow.vector.complex.ListVector
- getWriter() - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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.RunEndEncodedVector
-
Get a writer for this vector.
- getWriter() - Method in class org.apache.arrow.vector.complex.StructVector
- getWriter() - Method in class org.apache.arrow.vector.complex.UnionVector
- getWriter(Types.MinorType) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
-
Retrieve the FieldWriter, promoting if it is not a FieldWriter of the specified type
- getWriter(Types.MinorType, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- getWriter(Types.MinorType, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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 - Enum constant in enum org.apache.arrow.vector.types.FloatingPointPrecision
-
16-bit (not a standard java type).
- 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
- handleSafe(int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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(CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Executes the handshake against the Flight service.
- HANDSHAKE - Enum constant in enum org.apache.arrow.flight.FlightMethod
- HANDSHAKE_DESCRIPTOR_NAME - Static variable in class org.apache.arrow.flight.auth.AuthConstants
- hasAuthHandler() - Method in class org.apache.arrow.flight.auth.ClientAuthInterceptor
- hasBoolValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
bool bool_value = 2;
- hasBoolValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
bool bool_value = 2;
- hasBoolValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
bool bool_value = 2;
- 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.
- hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The catalog of the destination table to load data into.
- hasCatalog() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The catalog of the destination table to load data into.
- hasCatalog() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The catalog of the destination table to load data into.
- 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.
- hasDoubleValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
double double_value = 4;
- hasDoubleValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
double double_value = 4;
- hasDoubleValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
double double_value = 4;
- 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;
- hasErrors() - Method in class org.apache.arrow.flight.SetSessionOptionsResult
-
Report whether the error map has nonzero length.
- 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 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.CloseSessionRequest
- hashCode() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- hashCode() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue
- hashCode() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- hashCode() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- hashCode() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- hashCode() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- 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.PollInfo
- hashCode() - Method in class org.apache.arrow.flight.SetSessionOptionsResult.Error
- 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.CommandStatementIngest
- hashCode() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult
- 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() - Method in class org.apache.arrow.memory.util.hash.MurmurHasher
- hashCode() - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
- hashCode() - Method in class org.apache.arrow.vector.BufferLayout
- hashCode() - Method in class org.apache.arrow.vector.dictionary.Dictionary
- hashCode() - Method in class org.apache.arrow.vector.extension.OpaqueType
- 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.Float2Holder
-
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.NullableFloat2Holder
-
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.NullableViewVarBinaryHolder
-
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.NullableViewVarCharHolder
-
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.holders.ViewVarBinaryHolder
-
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.ViewVarCharHolder
-
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() - 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.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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.ArrowType.Utf8View
- 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 class org.apache.arrow.vector.BaseFixedWidthVector
- hashCode(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- hashCode(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
- hashCode(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- hashCode(int) - Method in class org.apache.arrow.vector.BitVector
- hashCode(int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- hashCode(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
- hashCode(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
- hashCode(int) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Get the hash code for the element at the given index.
- hashCode(int) - Method in class org.apache.arrow.vector.complex.ListVector
- hashCode(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Get the hash code for the element at the given index.
- hashCode(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- hashCode(int) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Returns hashCode of element in index with the default hasher.
- hashCode(int) - Method in class org.apache.arrow.vector.complex.StructVector
- hashCode(int) - Method in class org.apache.arrow.vector.complex.UnionVector
- hashCode(int) - Method in class org.apache.arrow.vector.extension.OpaqueVector
- hashCode(int) - Method in class org.apache.arrow.vector.NullVector
- hashCode(int) - Method in interface org.apache.arrow.vector.ValueVector
-
Returns hashCode of element in index with the default hasher.
- hashCode(int) - Method in class org.apache.arrow.vector.ZeroVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.BitVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.LargeListVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Get the hash code for the element at the given index.
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.ListVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Get the hash code for the element at the given index.
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Returns hashCode of element in index with the given hasher.
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.StructVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.complex.UnionVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.extension.OpaqueVector
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.NullVector
- hashCode(int, ArrowBufHasher) - Method in interface org.apache.arrow.vector.ValueVector
-
Returns hashCode of element in index with the given hasher.
- hashCode(int, ArrowBufHasher) - Method in class org.apache.arrow.vector.ZeroVector
- hashCode(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(long, long) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
-
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(ArrowBuf, 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 class org.apache.arrow.memory.util.hash.MurmurHasher
- hashCode(ArrowBuf, long, long) - Method in class org.apache.arrow.memory.util.hash.SimpleHasher
-
Calculates the hash code for a memory region.
- hashCode(ArrowBuf, long, long, int) - Static method in class org.apache.arrow.memory.util.hash.MurmurHasher
-
Calculates the hash code for a memory region.
- 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.
- hasInt64Value() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
sfixed64 int64_value = 3;
- hasInt64Value() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
sfixed64 int64_value = 3;
- hasInt64Value() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
sfixed64 int64_value = 3;
- hasNext() - Method in class org.apache.arrow.adapter.avro.AvroToArrowVectorIterator
- hasNext() - Method in class org.apache.arrow.adapter.jdbc.ArrowVectorIterator
- 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
- hasPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
-
Represents a (potentially updated) opaque handle for the prepared statement on the server.
- hasPreparedStatementHandle() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
-
Represents a (potentially updated) opaque handle for the prepared statement on the server.
- hasPreparedStatementHandle() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResultOrBuilder
-
Represents a (potentially updated) opaque handle for the prepared statement on the server.
- 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.
- hasSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The db_schema of the destination table to load data into.
- hasSchema() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The db_schema of the destination table to load data into.
- hasSchema() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The db_schema of the destination table to load data into.
- hasSession() - Method in class org.apache.arrow.flight.ServerSessionMiddleware
-
Check if there is an open session associated with this call.
- hasStringListValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- hasStringListValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- hasStringListValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- hasStringValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
string string_value = 1;
- hasStringValue() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
-
string string_value = 1;
- hasStringValue() - Method in interface org.apache.arrow.flight.impl.Flight.SessionOptionValueOrBuilder
-
string string_value = 1;
- hasTableDefinitionOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- hasTableDefinitionOptions() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
The behavior for handling the table definition.
- hasTableDefinitionOptions() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
The behavior for handling the table definition.
- 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.CommandStatementIngest.Builder
-
Perform the ingestion as part of this transaction.
- hasTransactionId() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
-
Perform the ingestion as part of this transaction.
- hasTransactionId() - Method in interface org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngestOrBuilder
-
Perform the ingestion as part of this transaction.
- 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
- 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(int, String, Object...) - Constructor for class org.apache.arrow.memory.util.HistoricalLog
-
Constructor.
- HistoricalLog(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 org.apache.arrow.flight.ServerSessionMiddleware.Session
- 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.NullableStructReaderImpl
- 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.Float2WriterImpl
- 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
- idx() - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- idx() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- IF_EXISTS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- IF_NOT_EXIST_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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 - Variable in class org.apache.arrow.algorithm.sort.VariableWidthOutOfPlaceVectorSorter
- 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
- 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() - 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.SparseMatrixIndexCSX
- 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() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
-
The type of values in indicesBuffer
- indicesType() - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
-
The type of values in indicesBuffers
- indicesType(Int) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
- indicesType(Int) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
- 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() - 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.SparseMatrixIndexCSX
- 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
- INITIAL_VIEW_VALUE_ALLOCATION - Static variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- initialDataBufferSize - Variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
- initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.ListVector
- initializeChildrenFromFields(List<Field>) - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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.RunEndEncodedVector
-
Initializes the child vectors to be later loaded with loadBuffers.
- 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
- INLINE_SIZE - Static variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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, byte[]) - Method in interface org.apache.arrow.flight.CallHeaders
-
Insert a metadata pair with the given value.
- insert(String, byte[]) - Method in class org.apache.arrow.flight.ErrorFlightMetadata
- insert(String, byte[]) - Method in class org.apache.arrow.flight.FlightCallHeaders
- insert(String, byte[]) - Method in class org.apache.arrow.flight.grpc.MetadataAdapter
- insert(String, String) - 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, String) - Method in class org.apache.arrow.flight.FlightCallHeaders
- insert(String, String) - 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 interface org.apache.arrow.vector.compression.CompressionCodec.Factory
-
This combines all the available factories registered as service providers in the module path.
- 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.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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.types.pojo.ArrowType.Utf8View
- INSTANCE - Static variable in class org.apache.arrow.vector.ZeroVector
- Int - Class in org.apache.arrow.flatbuf
- Int - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Int - Static variable in class org.apache.arrow.flatbuf.Type
- Int() - Constructor for class org.apache.arrow.flatbuf.Int
- Int(int, boolean) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Int
- INT - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- Int.Vector - Class in org.apache.arrow.flatbuf
- INT64_VALUE - Enum constant in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- INT64_VALUE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- integer() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- integer() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- integer(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- integer(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- integer(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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.
- 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(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.auth.ServerAuthInterceptor
- interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class org.apache.arrow.flight.grpc.ServerBackpressureThresholdInterceptor
- interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class org.apache.arrow.flight.grpc.ServerInterceptorAdapter
- INTERNAL - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
An internal/implementation error occurred.
- 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.CloseSessionRequest.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- 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.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.CommandStatementIngest.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- 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
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- internalGetMapFieldReflection(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- internalGetMutableMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- internalGetMutableMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- internalGetMutableMapFieldReflection(int) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- internalGetMutableMapFieldReflection(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- internalGetValueMap() - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
- internalGetValueMap() - Static method in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
- internalGetValueMap() - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
- internalGetValueMap() - Static method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
- 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.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
- internalGetValueMap() - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
- 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
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Interval - Static variable in class org.apache.arrow.flatbuf.Type
- Interval() - Constructor for class org.apache.arrow.flatbuf.Interval
- Interval(IntervalUnit) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Interval
- Interval.Vector - Class in org.apache.arrow.flatbuf
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- intervalDay() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- intervalDay(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- intervalDay(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- intervalDay(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- INTERVALDAY - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- intervalMonthDayNano() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- intervalMonthDayNano(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- intervalMonthDayNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- intervalMonthDayNano(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- INTERVALMONTHDAYNANO - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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
- IntervalUnit - Class in org.apache.arrow.flatbuf
- IntervalUnit - Enum in org.apache.arrow.vector.types
-
Resolutions for Interval Vectors.
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- intervalYear() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- intervalYear(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- intervalYear(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- intervalYear(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- INTERVALYEAR - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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 - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
One or more of the given arguments was invalid.
- INVALID_ARGUMENT - Static variable in class org.apache.arrow.flight.CallStatus
- INVALID_NAME - Enum constant in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
The given session option name is invalid.
- INVALID_NAME - Enum constant in enum org.apache.arrow.flight.SetSessionOptionsResult.ErrorValue
-
The given session option name is invalid.
- INVALID_NAME_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
The given session option name is invalid.
- INVALID_VALUE - Enum constant in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
The session option value or type is invalid.
- INVALID_VALUE - Enum constant in enum org.apache.arrow.flight.SetSessionOptionsResult.ErrorValue
-
The session option value or type is invalid.
- INVALID_VALUE_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
The session option value or type is invalid.
- 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
- InvalidExtensionMetadataException - Exception in org.apache.arrow.vector.extension
-
The extension metadata was malformed.
- InvalidExtensionMetadataException(String) - Constructor for exception org.apache.arrow.vector.extension.InvalidExtensionMetadataException
- InvalidExtensionMetadataException(String, Throwable) - Constructor for exception org.apache.arrow.vector.extension.InvalidExtensionMetadataException
- 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
- 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() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
-
Returns if the column is auto incremented.
- isAutoIncrement(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
-
Sets 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() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
-
Returns if the column is case-sensitive.
- isCaseSensitive(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
-
Sets if the column is case-sensitive.
- 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.
- isDebug() - Static method in class org.apache.arrow.memory.RootAllocator
- 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
- isEmpty() - Method in class org.apache.arrow.flight.SessionOptionValue
-
Check whether the SessionOptionValue is empty/valueless.
- isEmpty() - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
-
Returns whether this Map has no elements.
- 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
- isEmpty(int) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- isEmpty(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
-
Return if value at index is empty.
- isEmpty(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.LargeListViewVector
-
Check if an element at given index is an empty list.
- isEmpty(int) - Method in class org.apache.arrow.vector.complex.ListVector
-
Check if element at given index is empty list.
- isEmpty(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Check if an element at given index is an empty list.
- isEmptyStruct() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
-
This implementation returns
false
. - 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).
- isFixedBufferCount() - Method in class org.apache.arrow.vector.TypeLayout
-
Determines whether the buffer count is fixed for the given type.
- 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.CloseSessionRequest.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- isInitialized() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- 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.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.CommandStatementIngest.Builder
- isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult.Builder
- isInitialized() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- 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
- isNaN(short) - Static method in class org.apache.arrow.memory.util.Float16
-
Returns true if the specified half-precision float value represents a Not-a-Number, false otherwise.
- 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.BaseVariableWidthViewVector
-
Check if an element at given index is null.
- 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.LargeListViewVector
-
Check if an 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.ListViewVector
-
Check if an 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.RunEndEncodedVector
-
Check whether an element in the vector is null.
- 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(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
- 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.
- 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 class org.apache.arrow.memory.RootAllocator
- 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.flight.sql.FlightSqlColumnMetadata
-
Returns if the column is read only.
- isReadOnly(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
-
Sets 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.
- isSafe(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Check if the given index is within the current value capacity of the vector.
- isSearchable() - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata
-
Returns if the column is searchable.
- isSearchable(boolean) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
-
Sets if the column is searchable.
- 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 - 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.Float2Holder
- 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.NullableFloat2Holder
- 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.NullableViewVarBinaryHolder
- isSet - Variable in class org.apache.arrow.vector.holders.NullableViewVarCharHolder
- 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 - Variable in class org.apache.arrow.vector.holders.VarBinaryHolder
- isSet - Variable in class org.apache.arrow.vector.holders.VarCharHolder
- isSet - Variable in class org.apache.arrow.vector.holders.ViewVarBinaryHolder
- isSet - Variable in class org.apache.arrow.vector.holders.ViewVarCharHolder
- 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.Float2HolderReaderImpl
- isSet() - Method in class org.apache.arrow.vector.complex.impl.Float2ReaderImpl
- 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.NullableFloat2HolderReaderImpl
- 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.NullableViewVarBinaryHolderReaderImpl
- isSet() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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.UnionLargeListViewReader
- isSet() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- isSet() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewReader
- 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() - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- isSet() - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- isSet() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- isSet() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- 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.Float2Reader
- 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() - Method in interface org.apache.arrow.vector.complex.reader.ViewVarBinaryReader
- isSet() - Method in interface org.apache.arrow.vector.complex.reader.ViewVarCharReader
- isSet() - Method in class org.apache.arrow.vector.holders.DenseUnionHolder
- isSet() - Method in class org.apache.arrow.vector.holders.UnionHolder
- isSet(int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
-
Same as
BaseFixedWidthVector.isNull(int)
. - isSet(int) - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- isSet(int) - Method in class org.apache.arrow.vector.BaseVariableWidthVector
-
Same as
BaseVariableWidthVector.isNull(int)
. - isSet(int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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(int) - Method in class org.apache.arrow.vector.complex.LargeListVector
-
Same as
LargeListVector.isNull(int)
. - isSet(int) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Same as
LargeListViewVector.isNull(int)
. - isSet(int) - Method in class org.apache.arrow.vector.complex.ListVector
-
Same as
ListVector.isNull(int)
. - isSet(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Same as
ListViewVector.isNull(int)
. - 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
- 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(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.
- iter(AutoCloseable...) - Static method in class org.apache.arrow.util.AutoCloseables
-
Converts
ac
to aIterable
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.BaseLargeRepeatedValueViewVector
- iterator() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- iterator() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.UnionListReader
- 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.RunEndEncodedVector
- 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 theTypes
type. - JdbcFieldInfo(int, int, int) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
-
Builds a
JdbcFieldInfo
from theTypes
type, precision, and scale. - JdbcFieldInfo(int, int, int, int) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
-
Builds a
JdbcFieldInfo
from theTypes
type, nullability, precision, and scale. - JdbcFieldInfo(ResultSet) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
-
Builds a
JdbcFieldInfo
from the corresponding row from aDatabaseMetaData.getColumns(java.lang.String, java.lang.String, java.lang.String, java.lang.String)
ResultSet. - JdbcFieldInfo(ResultSetMetaData, int) - Constructor for class org.apache.arrow.adapter.jdbc.JdbcFieldInfo
-
Builds a
JdbcFieldInfo
from the correspondingResultSetMetaData
column. - 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
JdbcToArrowConfig
s. - 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(ParameterMetaData, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
-
Create Arrow
Schema
object for the given JDBCResultSetMetaData
. - jdbcToArrowSchema(ResultSetMetaData, Calendar) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
-
Create Arrow
Schema
object for the given JDBCResultSetMetaData
. - jdbcToArrowSchema(ResultSetMetaData, JdbcToArrowConfig) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
-
Create Arrow
Schema
object for the given JDBCResultSetMetaData
. - 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
thatJsonStringArrayList.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.ComplexWriterImpl
- key() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- LargeBinary - Static variable in class org.apache.arrow.flatbuf.Type
- LargeBinary() - Constructor for class org.apache.arrow.flatbuf.LargeBinary
- LargeBinary() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.LargeBinary
- LargeBinary.Vector - Class in org.apache.arrow.flatbuf
- LargeList - Class in org.apache.arrow.flatbuf
-
Same as List, but with 64-bit offsets, allowing to represent extremely large data values.
- LargeList - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- LargeList - Static variable in class org.apache.arrow.flatbuf.Type
- LargeList() - Constructor for class org.apache.arrow.flatbuf.LargeList
- LargeList() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.LargeList
- LARGELIST - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- LargeList.Vector - Class in org.apache.arrow.flatbuf
- largeListVector - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- LargeListView - Static variable in class org.apache.arrow.flatbuf.Type
- LargeListView() - Constructor for class org.apache.arrow.flatbuf.LargeListView
- LargeListView() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.LargeListView
- LARGELISTVIEW - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- LargeListView.Vector - Class in org.apache.arrow.flatbuf
- largeListViewVector - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- LargeListViewVector - Class in org.apache.arrow.vector.complex
-
A large list view vector contains lists of a specific type of elements.
- LargeListViewVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.LargeListViewVector
-
Constructs a new instance.
- LargeListViewVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.LargeListViewVector
-
Constructs a new instance.
- 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
- largeSizeBuffer() - 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- LargeUtf8 - Static variable in class org.apache.arrow.flatbuf.Type
- LargeUtf8() - Constructor for class org.apache.arrow.flatbuf.LargeUtf8
- LargeUtf8() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.LargeUtf8
- LargeUtf8.Vector - Class in org.apache.arrow.flatbuf
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- largeVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- largeVarBinary(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- largeVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- largeVarBinary(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- LARGEVARBINARY - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- largeVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- largeVarChar(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- largeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- largeVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- LARGEVARCHAR - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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.BaseVariableWidthViewVector
- 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 - Variable in class org.apache.arrow.vector.util.ReusableByteArray
- 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_WIDTH - Static variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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 - Variable in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
- list() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- list() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- list() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- list() - Method in class org.apache.arrow.vector.complex.impl.NullReader
- list() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- list() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- list() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- list() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- list() - 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() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- list(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- list(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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(String) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- list(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- list(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
- list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- list(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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 - Class in org.apache.arrow.flatbuf
- List - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- List - Static variable in class org.apache.arrow.flatbuf.Type
- List() - Constructor for class org.apache.arrow.flatbuf.List
- List() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.List
- LIST - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- LIST_ACTIONS - Enum constant in enum org.apache.arrow.flight.FlightMethod
- LIST_FLIGHTS - Enum constant in enum org.apache.arrow.flight.FlightMethod
- 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(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.
- 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 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, 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.
- 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(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
- 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 interface org.apache.arrow.flight.impl.FlightServiceGrpc.AsyncService
-
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.
- 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
StructOrListWriterImpl.listOfStruct(String)
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 - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- listView() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- listView() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- listView() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- listView() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- listView() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- listView() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- listView() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- listView(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- listView(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- ListView - Static variable in class org.apache.arrow.flatbuf.Type
- ListView() - Constructor for class org.apache.arrow.flatbuf.ListView
- ListView() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.ListView
- LISTVIEW - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- ListView.Vector - Class in org.apache.arrow.flatbuf
- listViewVector - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- ListViewVector - Class in org.apache.arrow.vector.complex
-
A list view vector contains lists of a specific type of elements.
- ListViewVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.ListViewVector
-
Constructs a new instance.
- ListViewVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.ListViewVector
-
Constructs a new instance.
- listViewWriter - Variable in class org.apache.arrow.vector.complex.impl.UnionWriter
- listWriter - Variable in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
-
Load the buffers associated with this Field.
- 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.ListViewVector
-
Load the buffers associated with this Field.
- loadFieldBuffers(ArrowFieldNode, List<ArrowBuf>) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Loads data in the vectors.
- 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.
- 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 - Enum constant in enum org.apache.arrow.vector.compression.CompressionUtil.CodecType
- 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.
- makeEmptySessionOptionValue() - Static method in class org.apache.arrow.flight.SessionOptionValueFactory
- makeSessionOptionValue(boolean) - Static method in class org.apache.arrow.flight.SessionOptionValueFactory
- makeSessionOptionValue(double) - Static method in class org.apache.arrow.flight.SessionOptionValueFactory
- makeSessionOptionValue(long) - Static method in class org.apache.arrow.flight.SessionOptionValueFactory
- makeSessionOptionValue(String) - Static method in class org.apache.arrow.flight.SessionOptionValueFactory
- makeSessionOptionValue(String[]) - Static method in class org.apache.arrow.flight.SessionOptionValueFactory
- makeSessionOptionValue(Flight.SessionOptionValue) - Static method in class org.apache.arrow.flight.SessionOptionValueFactory
-
Construct a SessionOptionValue from its Protobuf object representation.
- 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.LargeListViewVector
- makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.ListVector
- makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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.RunEndEncodedVector
-
Makes a new transfer pair used to transfer underlying buffers.
- 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.Float2Vector
-
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.ViewVarBinaryVector
-
Construct a TransferPair with a desired target vector of the same type.
- makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Construct a TransferPair with a desired target vector of the same type.
- makeTransferPair(ValueVector) - Method in class org.apache.arrow.vector.ZeroVector
- map() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- map() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- map() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- map() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- map() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- map() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- map() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- map() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- map() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- map() - 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- map(boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- map(boolean) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- map(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- map(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- map(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- map(String, boolean) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- map(String, boolean) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- Map - Class in org.apache.arrow.flatbuf
-
A Map is a logical nested type that is represented as List<entries: Struct<key: K, value: V>> In this layout, the keys and values are each respectively contiguous.
- Map - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Map - Static variable in class org.apache.arrow.flatbuf.Type
- Map() - Constructor for class org.apache.arrow.flatbuf.Map
- Map(boolean) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Map
- MAP - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- Map.Vector - Class in org.apache.arrow.flatbuf
- 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
- mapWriter - Variable in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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_DECIMAL_PRECISION - Static variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- MAX_DECIMAL256_PRECISION - Static variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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 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.unsafe.UnsafeAllocationManager
- MemoryUtil - Class in org.apache.arrow.memory.util
-
Utilities for memory related operations.
- 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(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionBeginSavepointResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionBeginTransactionResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionCancelQueryResult.Builder
-
Deprecated.
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedStatementRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedSubstraitPlanRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionEndTransactionRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetCrossReference.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetExportedKeys.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetPrimaryKeys.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetTables.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetXdbcTypeInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandPreparedStatementUpdate.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandStatementSubstraitPlan.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.DoPutPreparedStatementResult.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.SubstraitPlan.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- mergeFrom(Message) - 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(Message) - 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(Message) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- mergeFrom(Message) - 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(Message) - 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(Message) - 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(Message) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- mergeFrom(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- mergeFrom(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - 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(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- mergeFrom(Message) - 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(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- mergeFrom(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- mergeFrom(Message) - 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(Message) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- mergeFrom(Flight.Action) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
- mergeFrom(Flight.ActionType) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- mergeFrom(Flight.BasicAuth) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- mergeFrom(Flight.CancelFlightInfoRequest) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- mergeFrom(Flight.CancelFlightInfoResult) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- mergeFrom(Flight.CloseSessionRequest) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- mergeFrom(Flight.CloseSessionResult) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- mergeFrom(Flight.Criteria) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- mergeFrom(Flight.Empty) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- mergeFrom(Flight.FlightData) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- mergeFrom(Flight.FlightDescriptor) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- mergeFrom(Flight.FlightEndpoint) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- mergeFrom(Flight.FlightInfo) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- mergeFrom(Flight.GetSessionOptionsRequest) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- mergeFrom(Flight.GetSessionOptionsResult) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- mergeFrom(Flight.HandshakeRequest) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- mergeFrom(Flight.HandshakeResponse) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- mergeFrom(Flight.Location) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- mergeFrom(Flight.PollInfo) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- mergeFrom(Flight.PutResult) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- mergeFrom(Flight.RenewFlightEndpointRequest) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- mergeFrom(Flight.Result) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- mergeFrom(Flight.SchemaResult) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- mergeFrom(Flight.SessionOptionValue) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- mergeFrom(Flight.SessionOptionValue.StringListValue) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- mergeFrom(Flight.SetSessionOptionsRequest) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- mergeFrom(Flight.SetSessionOptionsResult) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- mergeFrom(Flight.SetSessionOptionsResult.Error) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- mergeFrom(Flight.Ticket) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- mergeFrom(FlightSql.ActionBeginSavepointRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
- mergeFrom(FlightSql.ActionBeginSavepointResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
- mergeFrom(FlightSql.ActionBeginTransactionRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
- mergeFrom(FlightSql.ActionBeginTransactionResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
- mergeFrom(FlightSql.ActionCancelQueryRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
-
Deprecated.
- mergeFrom(FlightSql.ActionCancelQueryResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
-
Deprecated.
- mergeFrom(FlightSql.ActionClosePreparedStatementRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
- mergeFrom(FlightSql.ActionCreatePreparedStatementRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
- mergeFrom(FlightSql.ActionCreatePreparedStatementResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
- mergeFrom(FlightSql.ActionCreatePreparedSubstraitPlanRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
- mergeFrom(FlightSql.ActionEndSavepointRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
- mergeFrom(FlightSql.ActionEndTransactionRequest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
- mergeFrom(FlightSql.CommandGetCatalogs) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
- mergeFrom(FlightSql.CommandGetCrossReference) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
- mergeFrom(FlightSql.CommandGetDbSchemas) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
- mergeFrom(FlightSql.CommandGetExportedKeys) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
- mergeFrom(FlightSql.CommandGetImportedKeys) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
- mergeFrom(FlightSql.CommandGetPrimaryKeys) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
- mergeFrom(FlightSql.CommandGetSqlInfo) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
- mergeFrom(FlightSql.CommandGetTables) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
- mergeFrom(FlightSql.CommandGetTableTypes) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
- mergeFrom(FlightSql.CommandGetXdbcTypeInfo) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
- mergeFrom(FlightSql.CommandPreparedStatementQuery) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
- mergeFrom(FlightSql.CommandPreparedStatementUpdate) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
- mergeFrom(FlightSql.CommandStatementIngest) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- mergeFrom(FlightSql.CommandStatementIngest.TableDefinitionOptions) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- mergeFrom(FlightSql.CommandStatementQuery) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
- mergeFrom(FlightSql.CommandStatementSubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
- mergeFrom(FlightSql.CommandStatementUpdate) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- mergeFrom(FlightSql.DoPutPreparedStatementResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- mergeFrom(FlightSql.DoPutUpdateResult) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
- mergeFrom(FlightSql.SubstraitPlan) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
- mergeFrom(FlightSql.TicketStatementQuery) - 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
- mergeStringListValue(Flight.SessionOptionValue.StringListValue) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- mergeTableDefinitionOptions(FlightSql.CommandStatementIngest.TableDefinitionOptions) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- 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.CloseSessionRequest.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.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.GetSessionOptionsRequest.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.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.SessionOptionValue.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.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.CommandStatementIngest.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.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.DoPutPreparedStatementResult.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 - Variable in class org.apache.arrow.vector.ipc.message.IpcOption
- MetadataVersion - Class in org.apache.arrow.flatbuf
- 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 - Enum constant in enum org.apache.arrow.vector.types.TimeUnit
- 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 - Enum constant in enum org.apache.arrow.vector.types.DateUnit
-
Milliseconds since epoch.
- MILLISECOND - Enum constant in enum org.apache.arrow.vector.types.TimeUnit
- 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
- MONTH_DAY_NANO - Enum constant in enum org.apache.arrow.vector.types.IntervalUnit
-
Values are stored as number of months, days and nanoseconds.
- 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 - Variable in class org.apache.arrow.vector.complex.AbstractContainerVector
- name() - Method in class org.apache.arrow.flatbuf.Field
-
Name is not required, in i.e.
- name() - Method in class org.apache.arrow.flatbuf.TensorDim
-
Name of the dimension, optional
- 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(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(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_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
- NaN - Static variable in class org.apache.arrow.memory.util.Float16
- NANOSECOND - Enum constant in enum org.apache.arrow.vector.types.TimeUnit
- 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
- needConvertToMessageFormat(Field) - Static method in class org.apache.arrow.vector.util.DictionaryUtility
-
Checks if it is required to convert the field to message format.
- Netty - Enum constant in enum org.apache.arrow.memory.DefaultAllocationManagerOption.AllocationManagerType
-
Netty based allocation manager.
- 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
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Action
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Location
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Result
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- newBuilder() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- newBuilder() - 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() - 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() - 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() - 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() - 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() - 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() - 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() - 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() - 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() - 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() - 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() - 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() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- newBuilder() - 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() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
- newBuilder() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- newBuilder() - 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() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- newBuilder(Flight.Action) - Static method in class org.apache.arrow.flight.impl.Flight.Action
- newBuilder(Flight.ActionType) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- newBuilder(Flight.BasicAuth) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- newBuilder(Flight.CancelFlightInfoRequest) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- newBuilder(Flight.CancelFlightInfoResult) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- newBuilder(Flight.CloseSessionRequest) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- newBuilder(Flight.CloseSessionResult) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- newBuilder(Flight.Criteria) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- newBuilder(Flight.Empty) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- newBuilder(Flight.FlightData) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- newBuilder(Flight.FlightDescriptor) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- newBuilder(Flight.FlightEndpoint) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- newBuilder(Flight.FlightInfo) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- newBuilder(Flight.GetSessionOptionsRequest) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- newBuilder(Flight.GetSessionOptionsResult) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- newBuilder(Flight.HandshakeRequest) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- newBuilder(Flight.HandshakeResponse) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- newBuilder(Flight.Location) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- newBuilder(Flight.PollInfo) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- newBuilder(Flight.PutResult) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- newBuilder(Flight.RenewFlightEndpointRequest) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- newBuilder(Flight.Result) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- newBuilder(Flight.SchemaResult) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- newBuilder(Flight.SessionOptionValue) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- newBuilder(Flight.SessionOptionValue.StringListValue) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- newBuilder(Flight.SetSessionOptionsRequest) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- newBuilder(Flight.SetSessionOptionsResult) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- newBuilder(Flight.SetSessionOptionsResult.Error) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- newBuilder(Flight.Ticket) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- newBuilder(FlightSql.ActionBeginSavepointRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
- newBuilder(FlightSql.ActionBeginSavepointResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
- newBuilder(FlightSql.ActionBeginTransactionRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
- newBuilder(FlightSql.ActionBeginTransactionResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
- newBuilder(FlightSql.ActionCancelQueryRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest
-
Deprecated.
- newBuilder(FlightSql.ActionCancelQueryResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult
-
Deprecated.
- newBuilder(FlightSql.ActionClosePreparedStatementRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
- newBuilder(FlightSql.ActionCreatePreparedStatementRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
- newBuilder(FlightSql.ActionCreatePreparedStatementResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
- newBuilder(FlightSql.ActionCreatePreparedSubstraitPlanRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
- newBuilder(FlightSql.ActionEndSavepointRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
- newBuilder(FlightSql.ActionEndTransactionRequest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
- newBuilder(FlightSql.CommandGetCatalogs) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
- newBuilder(FlightSql.CommandGetCrossReference) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
- newBuilder(FlightSql.CommandGetDbSchemas) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
- newBuilder(FlightSql.CommandGetExportedKeys) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
- newBuilder(FlightSql.CommandGetImportedKeys) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
- newBuilder(FlightSql.CommandGetPrimaryKeys) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
- newBuilder(FlightSql.CommandGetSqlInfo) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
- newBuilder(FlightSql.CommandGetTables) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
- newBuilder(FlightSql.CommandGetTableTypes) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
- newBuilder(FlightSql.CommandGetXdbcTypeInfo) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
- newBuilder(FlightSql.CommandPreparedStatementQuery) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
- newBuilder(FlightSql.CommandPreparedStatementUpdate) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
- newBuilder(FlightSql.CommandStatementIngest) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- newBuilder(FlightSql.CommandStatementIngest.TableDefinitionOptions) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- newBuilder(FlightSql.CommandStatementQuery) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
- newBuilder(FlightSql.CommandStatementSubstraitPlan) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
- newBuilder(FlightSql.CommandStatementUpdate) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
- newBuilder(FlightSql.DoPutPreparedStatementResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- newBuilder(FlightSql.DoPutUpdateResult) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
- newBuilder(FlightSql.SubstraitPlan) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
- 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() - Method in class org.apache.arrow.flight.impl.Flight.ActionType
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Criteria
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Empty
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightData
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Location
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.PutResult
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Result
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- newBuilderForType() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
- newBuilderForType() - 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() - 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() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- newBuilderForType() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
- newBuilderForType() - 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.impl.Flight.Action
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.ActionType
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Criteria
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Empty
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightData
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Location
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.PutResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Result
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.impl.Flight.Ticket
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - 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.ActionCancelQueryResult
-
Deprecated.
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- newChildAllocator(String, long, long) - Method in class org.apache.arrow.memory.RootAllocator
- newChildAllocator(String, long, long) - Method in interface org.apache.arrow.memory.BufferAllocator
-
Create a new child allocator.
- newChildAllocator(String, AllocationListener, long, long) - Method in class org.apache.arrow.memory.RootAllocator
- newChildAllocator(String, AllocationListener, long, long) - Method in interface org.apache.arrow.memory.BufferAllocator
-
Create a new child allocator.
- 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
- 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.CloseSessionRequest
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.impl.Flight.Ticket
- 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.CommandStatementIngest
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult
- 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. - newReservation() - Method in class org.apache.arrow.memory.RootAllocator
- newReservation() - Method in interface org.apache.arrow.memory.BufferAllocator
-
Create an allocation reservation.
- 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
- next() - Method in class org.apache.arrow.adapter.avro.AvroToArrowVectorIterator
-
Gets the next vector.
- 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.flight.FlightStream
-
Blocking request to load next item into list.
- next() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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.Float2HolderReaderImpl
- 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.NullableFloat2HolderReaderImpl
- 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.NullableViewVarBinaryHolderReaderImpl
- next() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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.UnionLargeListViewReader
- next() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- next() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewReader
- 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 class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- next() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- 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 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.
- NO_ACTION - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
NO_ACTION = 3;
- NO_ACTION_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
NO_ACTION = 3;
- NO_COMPRESSION - Enum constant in enum org.apache.arrow.vector.compression.CompressionUtil.CodecType
- 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.avro.AvroToArrowVectorIterator
- NO_LIMIT_BATCH_SIZE - Static variable in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfig
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- 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(String, BufferAllocator, FieldType, CallBack, AbstractStructVector.ConflictPolicy, boolean) - 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(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 method in class org.apache.arrow.util.AutoCloseables
-
Get an AutoCloseable that does nothing.
- NOOP - Static variable in interface org.apache.arrow.memory.AllocationListener
- 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
- NoOpSessionOptionValueVisitor<T> - Class in org.apache.arrow.flight
-
A helper to facilitate easier anonymous subclass declaration.
- NoOpSessionOptionValueVisitor() - Constructor for class org.apache.arrow.flight.NoOpSessionOptionValueVisitor
- 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_CANCELLABLE - Enum constant in enum org.apache.arrow.flight.CancelStatus
-
The query is not cancellable.
- NOT_CANCELLABLE - Enum constant in enum org.apache.arrow.flight.sql.CancelResult
-
Deprecated.
- NOT_CLOSABLE - Enum constant in enum org.apache.arrow.flight.CloseSessionResult.Status
-
The session is not closeable.
- NOT_CLOSEABLE - Enum constant in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
The session is not closeable.
- NOT_CLOSEABLE_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
The session is not closeable.
- NOT_FOUND - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The operation describes a resource that does not exist.
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Null - Static variable in class org.apache.arrow.flatbuf.Type
- Null() - Constructor for class org.apache.arrow.flatbuf.Null
- Null() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Null
- NULL - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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.
- Null.Vector - Class in org.apache.arrow.flatbuf
- NULLABILITY_NO_NULLS - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
-
Indicates that the fields does not allow the use of null values.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
-
Indicates that the fields 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
-
Indicates that nullability of the fields cannot be determined.
- 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
- NullableFloat2Holder - Class in org.apache.arrow.vector.holders
-
Source code generated using FreeMarker template ValueHolders.java
- NullableFloat2Holder() - Constructor for class org.apache.arrow.vector.holders.NullableFloat2Holder
- NullableFloat2HolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
- NullableFloat2HolderReaderImpl(NullableFloat2Holder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableFloat2HolderReaderImpl
- 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 - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- nullableStructWriterFactory - Variable in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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
- NullableViewVarBinaryHolder - Class in org.apache.arrow.vector.holders
-
Source code generated using FreeMarker template ValueHolders.java
- NullableViewVarBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.NullableViewVarBinaryHolder
- NullableViewVarBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
- NullableViewVarBinaryHolderReaderImpl(NullableViewVarBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableViewVarBinaryHolderReaderImpl
- NullableViewVarCharHolder - Class in org.apache.arrow.vector.holders
-
Source code generated using FreeMarker template ValueHolders.java
- NullableViewVarCharHolder() - Constructor for class org.apache.arrow.vector.holders.NullableViewVarCharHolder
- NullableViewVarCharHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
- NullableViewVarCharHolderReaderImpl(NullableViewVarCharHolder) - Constructor for class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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.
- 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() - Constructor for class org.apache.arrow.vector.NullVector
-
Deprecated.
- 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.
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 - Enum constant in enum org.apache.arrow.vector.BufferLayout.BufferType
- 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.BaseLargeRepeatedValueViewVector
- OFFSET_WIDTH - Static variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- OFFSET_WIDTH - Static variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.BaseLargeRepeatedValueViewVector
- offsetAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- offsetAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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 - Variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- offsetBuffer - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- offsetBuffer - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- offsetBuffer - Variable in class org.apache.arrow.vector.complex.LargeListVector
- offsetBuffer() - Static method in class org.apache.arrow.vector.BufferLayout
- ok() - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.ComplexReader
- OK - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The call completed successfully.
- 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
- onBeforeSendingHeaders(CallHeaders) - Method in class org.apache.arrow.flight.ServerSessionMiddleware
- 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
- onCallCompleted(CallStatus) - Method in class org.apache.arrow.flight.ServerSessionMiddleware
- 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
- onCallErrored(Throwable) - Method in class org.apache.arrow.flight.ServerSessionMiddleware
- onCallStarted(CallInfo) - Method in class org.apache.arrow.flight.auth2.ClientIncomingAuthHeaderMiddleware.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 class org.apache.arrow.flight.auth2.ServerCallHeaderAuthMiddleware.Factory
- 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
- onCallStarted(CallInfo, CallHeaders, RequestContext) - Method in class org.apache.arrow.flight.ServerSessionMiddleware.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.CloseSessionResultListener
- onCompleted() - Method in class org.apache.arrow.flight.sql.FlightEndpointListener
- onCompleted() - Method in class org.apache.arrow.flight.sql.GetSessionOptionsResultListener
- onCompleted() - Method in class org.apache.arrow.flight.sql.SetSessionOptionsResultListener
- 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.CloseSessionResultListener
- onError(Throwable) - Method in class org.apache.arrow.flight.sql.FlightEndpointListener
- onError(Throwable) - Method in class org.apache.arrow.flight.sql.GetSessionOptionsResultListener
- onError(Throwable) - Method in class org.apache.arrow.flight.sql.SetSessionOptionsResultListener
- 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(CloseSessionResult) - Method in class org.apache.arrow.flight.sql.CloseSessionResultListener
- onNext(FlightEndpoint) - Method in class org.apache.arrow.flight.sql.FlightEndpointListener
- onNext(GetSessionOptionsResult) - Method in class org.apache.arrow.flight.sql.GetSessionOptionsResultListener
- 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(PutResult) - Method in class org.apache.arrow.flight.SyncPutListener
- onNext(SetSessionOptionsResult) - Method in class org.apache.arrow.flight.sql.SetSessionOptionsResultListener
- 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.
- 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.
- OpaqueType - Class in org.apache.arrow.vector.extension
-
Opaque is a placeholder for a type from an external (usually non-Arrow) system that could not be interpreted.
- OpaqueType(ArrowType, String, String) - Constructor for class org.apache.arrow.vector.extension.OpaqueType
-
Create a new type instance.
- OpaqueVector - Class in org.apache.arrow.vector.extension
-
Opaque is a wrapper for (usually binary) data from an external (often non-Arrow) system that could not be interpreted.
- OpaqueVector(Field, BufferAllocator, FieldVector) - Constructor for class org.apache.arrow.vector.extension.OpaqueVector
- open() - Method in class org.apache.arrow.memory.util.AutoCloseableLock
- option - Variable in class org.apache.arrow.vector.ipc.ArrowWriter
- OPTIONS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- OPTIONVALUE_NOT_SET - Enum constant in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- 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
- ordinal - Variable in class org.apache.arrow.vector.complex.VectorWithOrdinal
- org.apache.arrow.adapter.avro - module org.apache.arrow.adapter.avro
- org.apache.arrow.adapter.avro - package org.apache.arrow.adapter.avro
- org.apache.arrow.adapter.avro.consumers - package org.apache.arrow.adapter.avro.consumers
- org.apache.arrow.adapter.avro.consumers.logical - package org.apache.arrow.adapter.avro.consumers.logical
- org.apache.arrow.adapter.jdbc - module org.apache.arrow.adapter.jdbc
- 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 - module org.apache.arrow.algorithm
- 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 - module org.apache.arrow.compression
- org.apache.arrow.compression - package org.apache.arrow.compression
- 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.core - module org.apache.arrow.flight.core
- 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.sql - module org.apache.arrow.flight.sql
- 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.format - module org.apache.arrow.format
- org.apache.arrow.memory - package org.apache.arrow.memory
-
Memory Allocation, Accounting and Management.
- org.apache.arrow.memory.core - module org.apache.arrow.memory.core
- org.apache.arrow.memory.rounding - package org.apache.arrow.memory.rounding
- org.apache.arrow.memory.unsafe - module org.apache.arrow.memory.unsafe
- org.apache.arrow.memory.unsafe - package org.apache.arrow.memory.unsafe
- 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 - module org.apache.arrow.tools
- org.apache.arrow.tools - package org.apache.arrow.tools
- org.apache.arrow.util - package org.apache.arrow.util
- org.apache.arrow.vector - module org.apache.arrow.vector
- 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.extension - package org.apache.arrow.vector.extension
- 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
- OTHER - Enum constant in enum org.apache.arrow.flight.BackpressureStrategy.WaitResult
-
Indicates that the wait was interrupted for a reason unrelated to the listener itself.
- 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) - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
- OutOfMemoryException(String, Throwable) - Constructor for exception org.apache.arrow.memory.OutOfMemoryException
- OutOfMemoryException(String, Throwable, boolean, boolean) - 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) - Constructor for exception org.apache.arrow.vector.util.OversizedAllocationException
- OversizedAllocationException(String, Throwable) - Constructor for exception org.apache.arrow.vector.util.OversizedAllocationException
- OversizedAllocationException(String, Throwable, boolean, boolean) - 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
- parent - Variable in class org.apache.arrow.memory.RootAllocator
-
The parent allocator.
- parentContainer - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- parseDelimitedFrom(InputStream) - 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) - 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) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseDelimitedFrom(InputStream) - 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) - 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) - 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) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseDelimitedFrom(InputStream) - 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) - 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) - 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) - 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) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseDelimitedFrom(InputStream) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseDelimitedFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseDelimitedFrom(InputStream) - 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) - 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.DoPutPreparedStatementResult
- parseDelimitedFrom(InputStream) - 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) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.ActionBeginSavepointResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.ActionBeginTransactionResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.ActionCancelQueryResult
-
Deprecated.
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedStatementRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.ActionEndTransactionRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetCrossReference
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetExportedKeys
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetPrimaryKeys
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetTables
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetXdbcTypeInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.CommandPreparedStatementUpdate
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.CommandStatementSubstraitPlan
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.DoPutPreparedStatementResult
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.SubstraitPlan
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Action
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(byte[]) - 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.ActionBeginSavepointResult
- parseFrom(byte[]) - 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.ActionBeginTransactionResult
- parseFrom(byte[]) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(byte[]) - 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.ActionCreatePreparedStatementRequest
- parseFrom(byte[]) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(byte[]) - 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.ActionEndTransactionRequest
- parseFrom(byte[]) - 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.CommandGetCrossReference
- parseFrom(byte[]) - 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.CommandGetExportedKeys
- parseFrom(byte[]) - 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.CommandGetPrimaryKeys
- parseFrom(byte[]) - 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.CommandGetTables
- parseFrom(byte[]) - 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.CommandGetXdbcTypeInfo
- parseFrom(byte[]) - 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.CommandPreparedStatementUpdate
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(byte[]) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(byte[]) - 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.CommandStatementSubstraitPlan
- parseFrom(byte[]) - 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.DoPutPreparedStatementResult
- parseFrom(byte[]) - 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.SubstraitPlan
- 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.impl.Flight.Action
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(byte[], ExtensionRegistryLite) - 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.ActionBeginSavepointResult
- parseFrom(byte[], ExtensionRegistryLite) - 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.ActionBeginTransactionResult
- parseFrom(byte[], ExtensionRegistryLite) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(byte[], ExtensionRegistryLite) - 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.ActionCreatePreparedStatementRequest
- parseFrom(byte[], ExtensionRegistryLite) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(byte[], ExtensionRegistryLite) - 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.ActionEndTransactionRequest
- parseFrom(byte[], ExtensionRegistryLite) - 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.CommandGetCrossReference
- parseFrom(byte[], ExtensionRegistryLite) - 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.CommandGetExportedKeys
- parseFrom(byte[], ExtensionRegistryLite) - 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.CommandGetPrimaryKeys
- parseFrom(byte[], ExtensionRegistryLite) - 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.CommandGetTables
- parseFrom(byte[], ExtensionRegistryLite) - 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.CommandGetXdbcTypeInfo
- parseFrom(byte[], ExtensionRegistryLite) - 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.CommandPreparedStatementUpdate
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(byte[], ExtensionRegistryLite) - 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.CommandStatementSubstraitPlan
- parseFrom(byte[], ExtensionRegistryLite) - 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.DoPutPreparedStatementResult
- parseFrom(byte[], ExtensionRegistryLite) - 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.SubstraitPlan
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Action
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(ByteString) - 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.ActionBeginSavepointResult
- parseFrom(ByteString) - 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.ActionBeginTransactionResult
- parseFrom(ByteString) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(ByteString) - 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.ActionCreatePreparedStatementRequest
- parseFrom(ByteString) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(ByteString) - 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.ActionEndTransactionRequest
- parseFrom(ByteString) - 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.CommandGetCrossReference
- parseFrom(ByteString) - 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.CommandGetExportedKeys
- parseFrom(ByteString) - 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.CommandGetPrimaryKeys
- parseFrom(ByteString) - 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.CommandGetTables
- parseFrom(ByteString) - 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.CommandGetXdbcTypeInfo
- parseFrom(ByteString) - 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.CommandPreparedStatementUpdate
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(ByteString) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(ByteString) - 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.CommandStatementSubstraitPlan
- parseFrom(ByteString) - 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.DoPutPreparedStatementResult
- parseFrom(ByteString) - 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.SubstraitPlan
- 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.impl.Flight.Action
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(ByteString, ExtensionRegistryLite) - 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.ActionBeginSavepointResult
- parseFrom(ByteString, ExtensionRegistryLite) - 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.ActionBeginTransactionResult
- parseFrom(ByteString, ExtensionRegistryLite) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(ByteString, ExtensionRegistryLite) - 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.ActionCreatePreparedStatementRequest
- parseFrom(ByteString, ExtensionRegistryLite) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(ByteString, ExtensionRegistryLite) - 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.ActionEndTransactionRequest
- parseFrom(ByteString, ExtensionRegistryLite) - 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.CommandGetCrossReference
- parseFrom(ByteString, ExtensionRegistryLite) - 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.CommandGetExportedKeys
- parseFrom(ByteString, ExtensionRegistryLite) - 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.CommandGetPrimaryKeys
- parseFrom(ByteString, ExtensionRegistryLite) - 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.CommandGetTables
- parseFrom(ByteString, ExtensionRegistryLite) - 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.CommandGetXdbcTypeInfo
- parseFrom(ByteString, ExtensionRegistryLite) - 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.CommandPreparedStatementUpdate
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(ByteString, ExtensionRegistryLite) - 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.CommandStatementSubstraitPlan
- parseFrom(ByteString, ExtensionRegistryLite) - 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.DoPutPreparedStatementResult
- parseFrom(ByteString, ExtensionRegistryLite) - 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.SubstraitPlan
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Action
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(CodedInputStream) - 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.ActionBeginSavepointResult
- parseFrom(CodedInputStream) - 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.ActionBeginTransactionResult
- parseFrom(CodedInputStream) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(CodedInputStream) - 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.ActionCreatePreparedStatementRequest
- parseFrom(CodedInputStream) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(CodedInputStream) - 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.ActionEndTransactionRequest
- parseFrom(CodedInputStream) - 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.CommandGetCrossReference
- parseFrom(CodedInputStream) - 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.CommandGetExportedKeys
- parseFrom(CodedInputStream) - 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.CommandGetPrimaryKeys
- parseFrom(CodedInputStream) - 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.CommandGetTables
- parseFrom(CodedInputStream) - 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.CommandGetXdbcTypeInfo
- parseFrom(CodedInputStream) - 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.CommandPreparedStatementUpdate
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(CodedInputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(CodedInputStream) - 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.CommandStatementSubstraitPlan
- parseFrom(CodedInputStream) - 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.DoPutPreparedStatementResult
- parseFrom(CodedInputStream) - 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.SubstraitPlan
- 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.impl.Flight.Action
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionBeginSavepointResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionBeginTransactionResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedStatementRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.ActionEndTransactionRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetCrossReference
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetExportedKeys
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetPrimaryKeys
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetTables
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandGetXdbcTypeInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandPreparedStatementUpdate
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.CommandStatementSubstraitPlan
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.DoPutPreparedStatementResult
- parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.SubstraitPlan
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Action
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(InputStream) - 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.ActionBeginSavepointResult
- parseFrom(InputStream) - 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.ActionBeginTransactionResult
- parseFrom(InputStream) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(InputStream) - 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.ActionCreatePreparedStatementRequest
- parseFrom(InputStream) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(InputStream) - 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.ActionEndTransactionRequest
- parseFrom(InputStream) - 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.CommandGetCrossReference
- parseFrom(InputStream) - 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.CommandGetExportedKeys
- parseFrom(InputStream) - 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.CommandGetPrimaryKeys
- parseFrom(InputStream) - 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.CommandGetTables
- parseFrom(InputStream) - 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.CommandGetXdbcTypeInfo
- parseFrom(InputStream) - 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.CommandPreparedStatementUpdate
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(InputStream) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(InputStream) - 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.CommandStatementSubstraitPlan
- parseFrom(InputStream) - 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.DoPutPreparedStatementResult
- parseFrom(InputStream) - 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.SubstraitPlan
- 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.impl.Flight.Action
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(InputStream, ExtensionRegistryLite) - 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.ActionBeginSavepointResult
- parseFrom(InputStream, ExtensionRegistryLite) - 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.ActionBeginTransactionResult
- parseFrom(InputStream, ExtensionRegistryLite) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(InputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedStatementRequest
- parseFrom(InputStream, ExtensionRegistryLite) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(InputStream, ExtensionRegistryLite) - 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.ActionEndTransactionRequest
- parseFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetCrossReference
- parseFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetExportedKeys
- parseFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetPrimaryKeys
- parseFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetTables
- parseFrom(InputStream, ExtensionRegistryLite) - 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.CommandGetXdbcTypeInfo
- parseFrom(InputStream, ExtensionRegistryLite) - 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.CommandPreparedStatementUpdate
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(InputStream, ExtensionRegistryLite) - 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.CommandStatementSubstraitPlan
- parseFrom(InputStream, ExtensionRegistryLite) - 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.DoPutPreparedStatementResult
- parseFrom(InputStream, ExtensionRegistryLite) - 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.SubstraitPlan
- parseFrom(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) - 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) - 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) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(ByteBuffer) - 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) - 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) - 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) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(ByteBuffer) - 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) - 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) - 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) - 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) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(ByteBuffer) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(ByteBuffer) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(ByteBuffer) - 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) - 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.DoPutPreparedStatementResult
- parseFrom(ByteBuffer) - 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) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Action
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.ActionType
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.BasicAuth
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Criteria
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Empty
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightData
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.FlightInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Location
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PollInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.PutResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Result
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SchemaResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.ActionBeginSavepointResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.ActionBeginTransactionResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.ActionCancelQueryResult
-
Deprecated.
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.ActionCreatePreparedStatementRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.ActionCreatePreparedSubstraitPlanRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.ActionEndTransactionRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.CommandGetCrossReference
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.CommandGetExportedKeys
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.CommandGetPrimaryKeys
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.CommandGetTables
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.CommandGetXdbcTypeInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.CommandPreparedStatementUpdate
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.CommandStatementSubstraitPlan
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.DoPutPreparedStatementResult
- parseFrom(ByteBuffer, ExtensionRegistryLite) - 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.SubstraitPlan
- parseFrom(ByteBuffer, 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.CloseSessionRequest
- parser() - Static method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- parser() - Static method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue
- parser() - Static method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- parser() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- parser() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- parser() - Static method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- parser() - Static method in class org.apache.arrow.flight.impl.Flight.Ticket
- 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.CommandStatementIngest
- parser() - Static method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions
- 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.DoPutPreparedStatementResult
- 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 - Enum constant in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
-
A named path that identifies a dataset.
- 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.
- 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.
- POLL_FLIGHT_INFO - Enum constant in enum org.apache.arrow.flight.FlightMethod
- 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) - 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 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, 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.
- 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 - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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.
- POSITIVE_INFINITY - Static variable in class org.apache.arrow.memory.util.Float16
- preAllocate(VectorSchemaRoot, int) - Static method in class org.apache.arrow.vector.util.ValueVectorUtility
-
Pre allocate memory for BaseFixedWidthVector.
- 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
- precision() - Method in class org.apache.arrow.flatbuf.Decimal
-
Total number of decimal digits
- precision() - Method in class org.apache.arrow.flatbuf.FloatingPoint
- precision(int) - Method in class org.apache.arrow.flight.sql.FlightSqlColumnMetadata.Builder
-
Sets the precision / column size.
- Precision - Class in org.apache.arrow.flatbuf
- 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).
- PREFIX_WIDTH - Static variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- 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.
- 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
- PREPARED_STATEMENT_HANDLE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult
- prepareLoadNextBatch() - Method in class org.apache.arrow.vector.ipc.ArrowReader
-
Ensure the reader has been initialized and reset the VectorSchemaRoot row count to 0.
- 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) - Method in class org.apache.arrow.memory.ArrowBuf
-
Print detailed information of this buffer into
sb
. - 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. - producer(FlightProducer) - Method in class org.apache.arrow.flight.FlightServer.Builder
- 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.
- PromotableViewWriter - Class in org.apache.arrow.vector.complex.impl
-
This FieldWriter implementation delegates all FieldWriter API calls to an inner FieldWriter.
- PromotableViewWriter(ValueVector, AbstractStructVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, AbstractStructVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, FixedSizeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, FixedSizeListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, LargeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, LargeListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, LargeListViewVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, LargeListViewVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, ListVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, ListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- PromotableViewWriter(ValueVector, ListViewVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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, FixedSizeListVector) - 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) - 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.
- PromotableWriter(ValueVector, LargeListViewVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
-
Constructs a new instance.
- PromotableWriter(ValueVector, LargeListViewVector, 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, ListVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
-
Constructs a new instance.
- PromotableWriter(ValueVector, ListViewVector) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
-
Constructs a new instance.
- PromotableWriter(ValueVector, ListViewVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.PromotableWriter
-
Constructs a new instance.
- PromotableWriter.State - Enum in org.apache.arrow.vector.complex.impl
- promoteToUnion() - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
- promoteToUnion() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- promoteToUnion() - Method in class org.apache.arrow.vector.complex.LargeListVector
- promoteToUnion() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- promoteToUnion() - Method in class org.apache.arrow.vector.complex.ListVector
- promoteToUnion() - Method in class org.apache.arrow.vector.complex.ListViewVector
- 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(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
- put(Dictionary) - Method in class org.apache.arrow.vector.dictionary.DictionaryProvider.MapDictionaryProvider
- put(V) - Method in class org.apache.arrow.memory.LowCostIdentityHashMap
-
Maps the specified key to the specified value.
- putAllErrors(Map<String, Flight.SetSessionOptionsResult.Error>) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- putAllOptions(Map<String, String>) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Backend-specific options.
- putAllSessionOptions(Map<String, Flight.SessionOptionValue>) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- putAllSessionOptions(Map<String, Flight.SessionOptionValue>) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- putByte(long, byte) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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.
- putErrors(String, Flight.SetSessionOptionsResult.Error) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- putErrorsBuilderIfAbsent(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- putInt(long, int) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- putLong(long, long) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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. - putOptions(String, String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Backend-specific options.
- PutResult - Class in org.apache.arrow.flight
-
A message from the server during a DoPut operation.
- putSessionOptions(String, Flight.SessionOptionValue) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- putSessionOptions(String, Flight.SessionOptionValue) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- putSessionOptionsBuilderIfAbsent(String) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- putSessionOptionsBuilderIfAbsent(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- putShort(long, short) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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() - 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.FixedSizeBinaryVector
-
Read the value at the given position to the given output buffer.
- 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(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.
- read(int, ReusableBuffer<?>) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Get the variable length element at the specified index using a ReusableBuffer.
- read(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Read the value at the given position to the given output buffer.
- read(int, ReusableBuffer<?>) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Read the value at the given position to the given output buffer.
- read(int, BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, DenseUnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
- read(int, DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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.UnionLargeListViewReader
- read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewReader
- read(int, UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(int, UnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
- read(int, VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(int, ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(int, ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(ByteBuffer) - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
- read(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntHolderReaderImpl
- read(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
- read(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(BigIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
- read(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitHolderReaderImpl
- read(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
- read(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(BitHolder) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
- read(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayHolderReaderImpl
- read(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
- read(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(DateDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
- read(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliHolderReaderImpl
- read(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
- read(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(DateMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
- read(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256HolderReaderImpl
- read(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
- read(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(Decimal256Holder) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
- read(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalHolderReaderImpl
- read(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
- read(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(DecimalHolder) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
- read(DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(DenseUnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
- read(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationHolderReaderImpl
- read(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
- read(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(DurationHolder) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
- read(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryHolderReaderImpl
- read(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
- read(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(FixedSizeBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
- read(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.Float2HolderReaderImpl
- read(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat2HolderReaderImpl
- read(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(Float2Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float2Reader
- read(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4HolderReaderImpl
- read(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
- read(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(Float4Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
- read(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8HolderReaderImpl
- read(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
- read(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(Float8Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
- read(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayHolderReaderImpl
- read(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
- read(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(IntervalDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
- read(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoHolderReaderImpl
- read(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
- read(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(IntervalMonthDayNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
- read(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearHolderReaderImpl
- read(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
- read(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(IntervalYearHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
- read(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntHolderReaderImpl
- read(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
- read(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(IntHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
- read(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryHolderReaderImpl
- read(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
- read(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(LargeVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
- read(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharHolderReaderImpl
- read(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
- read(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(LargeVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
- read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBigIntHolderReaderImpl
- read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableBigIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.BigIntReader
- read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableBitHolderReaderImpl
- read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableBitHolder) - Method in interface org.apache.arrow.vector.complex.reader.BitReader
- read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateDayHolderReaderImpl
- read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableDateDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateDayReader
- read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDateMilliHolderReaderImpl
- read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableDateMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.DateMilliReader
- read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimal256HolderReaderImpl
- read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableDecimal256Holder) - Method in interface org.apache.arrow.vector.complex.reader.Decimal256Reader
- read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDecimalHolderReaderImpl
- read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableDecimalHolder) - Method in interface org.apache.arrow.vector.complex.reader.DecimalReader
- read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableDurationHolderReaderImpl
- read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableDurationHolder) - Method in interface org.apache.arrow.vector.complex.reader.DurationReader
- read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableFixedSizeBinaryHolderReaderImpl
- read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableFixedSizeBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.FixedSizeBinaryReader
- read(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.Float2HolderReaderImpl
- read(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.Float2ReaderImpl
- read(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat2HolderReaderImpl
- read(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableFloat2Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float2Reader
- read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat4HolderReaderImpl
- read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableFloat4Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float4Reader
- read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableFloat8HolderReaderImpl
- read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableFloat8Holder) - Method in interface org.apache.arrow.vector.complex.reader.Float8Reader
- read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalDayHolderReaderImpl
- read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableIntervalDayHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalDayReader
- read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalMonthDayNanoHolderReaderImpl
- read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableIntervalMonthDayNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalMonthDayNanoReader
- read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntervalYearHolderReaderImpl
- read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableIntervalYearHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntervalYearReader
- read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableIntHolderReaderImpl
- read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.IntReader
- read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarBinaryHolderReaderImpl
- read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableLargeVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarBinaryReader
- read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- 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(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableLargeVarCharHolderReaderImpl
- read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableLargeVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
- read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
- read(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableSmallIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
- read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
- read(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
- read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
- read(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
- read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
- read(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
- read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
- read(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
- read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
- read(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
- read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
- read(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampMicroTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
- read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
- read(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
- read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
- read(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampMilliTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
- read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
- read(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
- read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
- read(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampNanoTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
- read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
- read(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
- read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
- read(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTimeStampSecTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
- read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
- read(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableTinyIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
- read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
- read(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableUInt1Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
- read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
- read(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableUInt2Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
- read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
- read(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableUInt4Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
- read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
- read(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableUInt8Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
- read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
- read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- 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(NullableVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
- read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
- read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- 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(NullableVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
- read(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarBinaryHolderReaderImpl
- read(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- read(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- read(NullableViewVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarBinaryReader
- read(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- read(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- read(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- read(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- read(NullableViewVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarCharReader
- read(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
- read(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntHolderReaderImpl
- read(SmallIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
- read(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMicroHolderReaderImpl
- read(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroHolderReaderImpl
- read(TimeMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMicroReader
- read(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeMilliHolderReaderImpl
- read(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliHolderReaderImpl
- read(TimeMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeMilliReader
- read(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeNanoHolderReaderImpl
- read(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoHolderReaderImpl
- read(TimeNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeNanoReader
- read(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeSecHolderReaderImpl
- read(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecHolderReaderImpl
- read(TimeSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeSecReader
- read(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroHolderReaderImpl
- read(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroHolderReaderImpl
- read(TimeStampMicroHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroReader
- read(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMicroTZHolderReaderImpl
- read(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZHolderReaderImpl
- read(TimeStampMicroTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMicroTZReader
- read(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliHolderReaderImpl
- read(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliHolderReaderImpl
- read(TimeStampMilliHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliReader
- read(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampMilliTZHolderReaderImpl
- read(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZHolderReaderImpl
- read(TimeStampMilliTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampMilliTZReader
- read(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoHolderReaderImpl
- read(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoHolderReaderImpl
- read(TimeStampNanoHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoReader
- read(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampNanoTZHolderReaderImpl
- read(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZHolderReaderImpl
- read(TimeStampNanoTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampNanoTZReader
- read(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecHolderReaderImpl
- read(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecHolderReaderImpl
- read(TimeStampSecHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecReader
- read(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTimeStampSecTZHolderReaderImpl
- read(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZHolderReaderImpl
- read(TimeStampSecTZHolder) - Method in interface org.apache.arrow.vector.complex.reader.TimeStampSecTZReader
- read(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableTinyIntHolderReaderImpl
- read(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntHolderReaderImpl
- read(TinyIntHolder) - Method in interface org.apache.arrow.vector.complex.reader.TinyIntReader
- read(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt1HolderReaderImpl
- read(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1HolderReaderImpl
- read(UInt1Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt1Reader
- read(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
- read(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2HolderReaderImpl
- read(UInt2Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt2Reader
- read(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt4HolderReaderImpl
- read(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4HolderReaderImpl
- read(UInt4Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt4Reader
- read(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullableUInt8HolderReaderImpl
- read(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8HolderReaderImpl
- read(UInt8Holder) - Method in interface org.apache.arrow.vector.complex.reader.UInt8Reader
- read(UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(UnionHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- read(UnionHolder) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader
- read(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarBinaryHolderReaderImpl
- read(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryHolderReaderImpl
- read(VarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarBinaryReader
- read(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableVarCharHolderReaderImpl
- read(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharHolderReaderImpl
- read(VarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
- read(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarBinaryHolderReaderImpl
- read(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- read(ViewVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarBinaryReader
- read(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- read(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- read(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- read(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- read(ViewVarCharHolder) - Method in interface org.apache.arrow.vector.complex.reader.ViewVarCharReader
- read(VectorSchemaRoot) - Method in class org.apache.arrow.vector.ipc.JsonFileReader
-
Reads the next record batch from the file into
root
. - 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.NullableStructReaderImpl
- 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() - 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
- readBigDecimal(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readBigDecimal(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readBoolean() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - 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
- readBoolean(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readBoolean(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readByte() - Method in class org.apache.arrow.memory.ArrowBuf
-
Read the byte at readerIndex.
- readByte() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - 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
- readByte(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readByte(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readByteArray() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarBinaryHolderReaderImpl
- 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 class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- readByteArray() - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- 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
- readByteArray() - Method in interface org.apache.arrow.vector.complex.reader.ViewVarBinaryReader
- readByteArray(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readByteArray(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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.NullableStructReaderImpl
- readCharacter() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- readCharacter() - Method in class org.apache.arrow.vector.complex.impl.NullableUInt2HolderReaderImpl
- 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
- readCharacter(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readCharacter(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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.NullableStructReaderImpl
- 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() - 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
- readDouble(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readDouble(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readDuration() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - 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
- readDuration(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readDuration(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- reader - Variable in class org.apache.arrow.vector.complex.LargeListVector
- reader - Variable in class org.apache.arrow.vector.complex.LargeListViewVector
- reader - Variable in class org.apache.arrow.vector.complex.ListVector
- reader - Variable in class org.apache.arrow.vector.complex.ListViewVector
- 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
- reader() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- reader() - Method in class org.apache.arrow.vector.complex.impl.NullReader
- reader() - Method in class org.apache.arrow.vector.complex.impl.SingleListReaderImpl
- 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.UnionLargeListViewReader
- reader() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- reader() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewReader
- reader() - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- 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(byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- reader(byte, String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- reader(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- reader(String) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- reader(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructReaderImpl
- reader(String) - Method in class org.apache.arrow.vector.complex.impl.UnionReader
- reader(String) - Method in interface org.apache.arrow.vector.complex.reader.BaseReader.StructReader
- 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.NullableStructReaderImpl
- 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() - 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
- readFloat(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readFloat(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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.NullableStructReaderImpl
- 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() - 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
- readInteger(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readInteger(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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.NullableStructReaderImpl
- 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() - 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
- readLocalDateTime(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readLocalDateTime(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readLong() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - 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
- readLong(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readLong(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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.Float2HolderReaderImpl
- readObject() - Method in class org.apache.arrow.vector.complex.impl.Float2ReaderImpl
- 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.NullableFloat2HolderReaderImpl
- 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() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarBinaryHolderReaderImpl
- readObject() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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.UnionLargeListViewReader
- readObject() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- readObject() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewReader
- 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 class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- readObject() - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- readObject() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- readObject() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- 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.Float2Reader
- 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
- readObject() - Method in interface org.apache.arrow.vector.complex.reader.ViewVarBinaryReader
- readObject() - Method in interface org.apache.arrow.vector.complex.reader.ViewVarCharReader
- readObject(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readObject(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readPeriod() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - 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
- readPeriod(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readPeriod(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readPeriodDuration() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - 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
- readPeriodDuration(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readPeriodDuration(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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.NullableStructReaderImpl
- readShort() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionReader
- readShort() - Method in class org.apache.arrow.vector.complex.impl.Float2HolderReaderImpl
- readShort() - Method in class org.apache.arrow.vector.complex.impl.Float2ReaderImpl
- readShort() - Method in class org.apache.arrow.vector.complex.impl.NullableFloat2HolderReaderImpl
- readShort() - Method in class org.apache.arrow.vector.complex.impl.NullableSmallIntHolderReaderImpl
- 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.Float2Reader
- readShort() - Method in interface org.apache.arrow.vector.complex.reader.SmallIntReader
- readShort(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readShort(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readString() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readString() - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readString(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readString(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- readText() - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- 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() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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 class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- readText() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- readText() - Method in interface org.apache.arrow.vector.complex.reader.LargeVarCharReader
- readText() - Method in interface org.apache.arrow.vector.complex.reader.VarCharReader
- readText() - Method in interface org.apache.arrow.vector.complex.reader.ViewVarCharReader
- readText(int) - Method in class org.apache.arrow.vector.complex.impl.NullableStructReaderImpl
- readText(int) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- 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.
- READY - Enum constant in enum org.apache.arrow.flight.BackpressureStrategy.WaitResult
-
Listener is ready.
- 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.BaseVariableWidthViewVector
-
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.BaseLargeRepeatedValueViewVector
- reAlloc() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- reAlloc() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.LargeListViewVector
- 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.ListViewVector
- reAlloc() - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Allocate new buffer with double capacity, and copy data into the new buffer.
- 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.
- reallocateBuffers() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- reallocateBuffers() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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 thanArrowBuf.capacity()
, otherwise delegates toBufferManager.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
- reallocValidityAndSizeAndOffsetBuffers() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- reallocValidityAndSizeAndOffsetBuffers() - Method in class org.apache.arrow.vector.complex.ListViewVector
- reallocValidityBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Reallocate Validity buffer.
- reallocViewBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Reallocate the view buffer.
- reallocViewBuffer(long) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Reallocate the view buffer to given size.
- reallocViewDataBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Reallocate the data buffer associated with view buffer.
- reallocViewDataBuffer(long) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Reallocate the data buffer for views.
- RECORD_COUNT_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult
- RecordBatch - Class in org.apache.arrow.flatbuf
-
A data header describing the shared memory layout of a "record" or "row" batch.
- RecordBatch - Static variable in class org.apache.arrow.flatbuf.MessageHeader
- 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.
- 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(ExtensionRegistry) - Static method in class org.apache.arrow.flight.impl.Flight
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql
- registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.impl.Flight
- registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.arrow.flight.sql.impl.FlightSql
- registerNewTypeId(Field) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- release() - Method in class org.apache.arrow.memory.BufferLedger
-
Decrement the ledger's reference count by 1 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 class org.apache.arrow.memory.BufferLedger
-
Decrement the ledger's reference count for the associated underlying memory chunk.
- release(int) - Method in interface org.apache.arrow.memory.ReferenceManager
-
Decrement this reference manager's reference count for the associated underlying memory.
- release(FlightSqlClient.Savepoint, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Release a savepoint.
- 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.unsafe.UnsafeAllocationManager
- releaseBuffer(ArrowBuf) - Method in class org.apache.arrow.vector.BaseValueVector
- releaseBytes(long) - Method in class org.apache.arrow.memory.RootAllocator
- releaseBytes(long) - Method in interface org.apache.arrow.memory.BufferAllocator
-
Release bytes from this allocator.
- 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
- removeEndpoint(int) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
-
A list of endpoints associated with the flight.
- removeErrors(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SetSessionOptionsResult.Error> errors = 1;
- 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().
- removeOptions(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Backend-specific options.
- removeSessionOptions(String) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- removeSessionOptions(String) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
-
map<string, .arrow.flight.protocol.SessionOptionValue> session_options = 1;
- 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.
- 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
- repeatedCallBack - Variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- repeatedCallBack - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- repeatedCallBack - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- RepeatedFixedWidthVectorLike - Interface in org.apache.arrow.vector.complex
-
A
ValueVector
mix-in that can be used in conjunction withRepeatedValueVector
subtypes. - RepeatedListHolder - Class in org.apache.arrow.vector.holders
-
ValueHolder
for a nestedListVector
. - 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 variableRepeatedValueVector
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.BaseLargeRepeatedValueViewVector
- replaceDataVector(FieldVector) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- replaceDataVector(FieldVector) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- replaceDataVector(FieldVector) - Method in class org.apache.arrow.vector.complex.LargeListVector
- reportUnsupportedTypesAsOpaque(Function<JdbcFieldInfo, ArrowType>, String) - Static method in class org.apache.arrow.adapter.jdbc.JdbcToArrowUtils
-
Wrap a JDBC to Arrow type converter such that
UnsupportedOperationException
becomesOpaqueType
. - 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
- requiresArrowType(Types.MinorType) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- reservation - Variable in class org.apache.arrow.memory.RootAllocator
-
The amount of memory reserved for this allocator.
- reserve(int) - Method in interface org.apache.arrow.memory.AllocationReservation
-
Deprecated, for removal: This API element is subject to removal in a future version.use
AllocationReservation.reserve(long)
instead - reserve(long) - 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.BaseVariableWidthViewVector
-
Reset the vector to initial state.
- reset() - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- reset() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- reset() - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- 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.NullableStructReaderImpl
- 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.LargeListViewVector
-
Release the buffers associated with this vector.
- reset() - Method in class org.apache.arrow.vector.complex.ListVector
- reset() - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Release the buffers associated with this vector.
- 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.RunEndEncodedVector
-
Reset the ValueVector to the initial state without releasing any owned ArrowBuf.
- 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.adapter.avro.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.avro.consumers.AvroArraysConsumer
- resetValueVector(ListVector) - Method in class org.apache.arrow.adapter.jdbc.consumer.ArrayConsumer
- resetValueVector(MapVector) - Method in class org.apache.arrow.adapter.avro.consumers.AvroMapConsumer
- resetValueVector(StructVector) - Method in class org.apache.arrow.adapter.avro.consumers.AvroStructConsumer
- resetValueVector(UnionVector) - Method in class org.apache.arrow.adapter.avro.consumers.AvroUnionsConsumer
- resetValueVector(FieldVector) - Method in class org.apache.arrow.adapter.avro.consumers.SkipConsumer
- resetValueVector(ValueVector) - Method in class org.apache.arrow.adapter.jdbc.consumer.CompositeJdbcConsumer
- 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(T) - Method in class org.apache.arrow.adapter.avro.consumers.BaseAvroConsumer
- resetValueVector(T) - Method in interface org.apache.arrow.adapter.avro.consumers.Consumer
-
Reset the vector within consumer for partial read purpose.
- resetValueVector(T) - Method in interface org.apache.arrow.adapter.jdbc.consumer.JdbcConsumer
-
Reset the vector within consumer for partial read purpose.
- resetValueVector(V) - Method in class org.apache.arrow.adapter.jdbc.consumer.BaseConsumer
- resetVectorSchemaRoot(VectorSchemaRoot) - Method in class org.apache.arrow.adapter.jdbc.consumer.CompositeJdbcConsumer
-
Reset inner consumers through vectors in the vector schema root.
- RESOURCE_EXHAUSTED - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
Some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
- RESOURCE_EXHAUSTED - Static variable in class org.apache.arrow.flight.CallStatus
- RESTRICT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
RESTRICT = 1;
- 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 org.apache.arrow.memory.BufferLedger
-
Increment the ledger's reference count for associated underlying memory chunk by 1.
- 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 class org.apache.arrow.memory.BufferLedger
-
Increment the ledger's reference count for associated underlying memory chunk by the given amount.
- 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 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(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.
- 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
- REUSE_CONNECTION - Static variable in class org.apache.arrow.flight.LocationSchemes
- reuseConnection() - Static method in class org.apache.arrow.flight.Location
-
Construct a special URI to indicate to clients that they may fetch data by reusing an existing connection to a Flight RPC server.
- rollback(FlightSqlClient.Savepoint, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Rollback to a savepoint.
- rollback(FlightSqlClient.Transaction, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
-
Rollback a transaction.
- 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
- rootAsListView() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- rootAsListView() - 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.
- roundUpToMultipleOf16(long) - Static method in class org.apache.arrow.vector.util.DataSizeRoundingUtil
- Row - Class in org.apache.arrow.vector.table
-
Row is a positionable, immutable cursor backed by a
Table
. - Row - Static variable in class org.apache.arrow.flatbuf.SparseMatrixCompressedAxis
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- RunEndEncoded - Static variable in class org.apache.arrow.flatbuf.Type
- RunEndEncoded() - Constructor for class org.apache.arrow.flatbuf.RunEndEncoded
- RunEndEncoded() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.RunEndEncoded
- RUNENDENCODED - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- RunEndEncoded.Vector - Class in org.apache.arrow.flatbuf
- RunEndEncodedVector - Class in org.apache.arrow.vector.complex
-
A run-end encoded vector contains only two child vectors: a run_end vector of type int and a values vector of any type.
- RunEndEncodedVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Constructs a new instance.
- RunEndEncodedVector(Field, BufferAllocator, FieldVector, FieldVector, CallBack) - Constructor for class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Constructs a new instance.
- RunEndEncodedVector(Field, BufferAllocator, CallBack) - Constructor for class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Constructs a new instance.
- runEndsVector - Variable in class org.apache.arrow.vector.complex.RunEndEncodedVector
S
- Savepoint(byte[]) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.Savepoint
- 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
- 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
- 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.
- 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() - Method in class org.apache.arrow.flatbuf.Footer
- schema(Schema) - Method in class org.apache.arrow.flatbuf.Footer
- Schema - Class in org.apache.arrow.flatbuf
-
---------------------------------------------------------------------- A Schema describes the columns in a row batch
- Schema - Class in org.apache.arrow.vector.types.pojo
-
An Arrow Schema.
- Schema - Static variable in class org.apache.arrow.flatbuf.MessageHeader
- Schema() - Constructor for class org.apache.arrow.flatbuf.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_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.sql.impl.FlightSql.CommandStatementIngest
- Schema.Vector - Class in org.apache.arrow.flatbuf
- 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) - Constructor for exception org.apache.arrow.vector.util.SchemaChangeRuntimeException
- SchemaChangeRuntimeException(String, Throwable) - Constructor for exception org.apache.arrow.vector.util.SchemaChangeRuntimeException
- SchemaChangeRuntimeException(String, Throwable, boolean, boolean) - 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
-
Indicates that column cannot be used in a WHERE clause.
- 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 - Enum constant in enum org.apache.arrow.vector.types.TimeUnit
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.use
SegmentRoundingPolicy(long)
instead. - SegmentRoundingPolicy(long) - 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.CloseSessionRequest
-
Get the serialized form of this protocol message.
- serialize() - Method in class org.apache.arrow.flight.CloseSessionResult
-
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.GetSessionOptionsRequest
-
Get the serialized form of this protocol message.
- serialize() - Method in class org.apache.arrow.flight.GetSessionOptionsResult
-
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.SetSessionOptionsRequest
-
Get the serialized form of this protocol message.
- serialize() - Method in class org.apache.arrow.flight.SetSessionOptionsResult
-
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() - Method in class org.apache.arrow.vector.extension.OpaqueType
- serialize() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
-
Save any metadata for this type.
- serialize(FBSerializable) - Static method in class org.apache.arrow.vector.ipc.WriteChannel
-
Serializes writer to a ByteBuffer.
- 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(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, 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(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(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 aMessage
. - 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.
- 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)
andCallHeaderAuthenticator
. - 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
- ServerBackpressureThresholdInterceptor - Class in org.apache.arrow.flight.grpc
-
An interceptor for specifying the number of bytes that can be queued before a call with an output stream gets blocked by backpressure.
- ServerBackpressureThresholdInterceptor(int) - Constructor for class org.apache.arrow.flight.grpc.ServerBackpressureThresholdInterceptor
- 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.
- ServerSessionMiddleware - Class in org.apache.arrow.flight
-
Middleware for handling Flight SQL Sessions including session cookie handling.
- ServerSessionMiddleware.Factory - Class in org.apache.arrow.flight
-
Factory for managing and accessing ServerSessionMiddleware.
- ServerSessionMiddleware.Session - Class in org.apache.arrow.flight
-
A thread-safe container for named SessionOptionValues.
- SERVICE - Static variable in interface org.apache.arrow.flight.FlightConstants
- SERVICE_NAME - Static variable in class org.apache.arrow.flight.impl.FlightServiceGrpc
- SESSION_OPTIONS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- SESSION_OPTIONS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- sessionCookieName - Static variable in class org.apache.arrow.flight.ServerSessionMiddleware
- SessionOptionValue - Class in org.apache.arrow.flight
-
A union-like container interface for supported session option value types.
- SessionOptionValueFactory - Class in org.apache.arrow.flight
-
Abstract factory for concrete SessionOptionValue instances.
- SessionOptionValueFactory() - Constructor for class org.apache.arrow.flight.SessionOptionValueFactory
- SessionOptionValueVisitor<T> - Interface in org.apache.arrow.flight
-
A visitor interface to access SessionOptionValue's contained value.
- set(byte[]) - Method in class org.apache.arrow.vector.util.Text
-
Set to an utf8 byte array.
- set(byte[], int, int) - Method in class org.apache.arrow.vector.util.Text
-
Set the Text to range of bytes.
- set(byte[], long, long) - Method in interface org.apache.arrow.memory.ReusableBuffer
- set(byte[], long, long) - Method in class org.apache.arrow.vector.util.ReusableByteArray
- set(int, byte) - 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.UInt1Vector
-
Set the element at the given index to the given value.
- 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[]) - 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[]) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Set the variable length element at the specified index to the supplied byte array.
- set(int, byte[]) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
-
Sets the value at index to the provided one.
- set(int, byte[]) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
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.BaseFixedWidthVector
- 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, 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, byte[], int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Set the variable length element at the specified index to the supplied byte array.
- set(int, byte[], int, int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Set the variable length element at the specified index to the supplied byte array.
- set(int, char) - Method in class org.apache.arrow.vector.UInt2Vector
-
Set the element at the given index to the given value.
- set(int, double) - Method in class org.apache.arrow.vector.Float8Vector
-
Set the element at the given index to the given value.
- set(int, float) - Method in class org.apache.arrow.vector.Float4Vector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.BitVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.DateDayVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.IntervalYearVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.IntVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.SmallIntVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.TimeMilliVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.TimeSecVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.TinyIntVector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.UInt1Vector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.UInt2Vector
-
Set the element at the given index to the given value.
- set(int, int) - Method in class org.apache.arrow.vector.UInt4Vector
-
Set the element at the given index to the given value.
- 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, 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, 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, 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, double) - Method in class org.apache.arrow.vector.Float8Vector
-
Store the given value at a particular position in the vector.
- 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, int, int) - Method in class org.apache.arrow.vector.BitVector
-
Store the given value at a particular position in the vector.
- 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, int, int) - 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.IntervalYearVector
-
Store the given value at a particular position in the vector.
- 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, int, int) - Method in class org.apache.arrow.vector.TimeMilliVector
-
Store the given value at a particular position in the vector.
- 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, 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, int, int, int) - Method in class org.apache.arrow.vector.IntervalDayVector
-
Store the given value at a particular position in the vector.
- 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, 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, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Store the given value at a particular position in the vector.
- 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, 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.BaseVariableWidthViewVector
-
Store the given value at a particular position in the vector.
- 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, long) - Method in class org.apache.arrow.vector.DateMilliVector
-
Store the given value at a particular position in the vector.
- 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, int, long) - Method in class org.apache.arrow.vector.TimeMicroVector
-
Store the given value at a particular position in the vector.
- 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, long) - Method in class org.apache.arrow.vector.TimeStampVector
-
Store the given value at a particular position in the vector.
- 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(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, int, long, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
-
Store the given value at a particular position in the vector.
- 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, int, short) - Method in class org.apache.arrow.vector.Float2Vector
-
Store the given value at a particular position in the vector.
- 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, int, ArrowBuf) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
-
Set the element at the given index to the given value.
- set(int, long) - Method in class org.apache.arrow.vector.BigIntVector
-
Set the element at the given index to the given value.
- set(int, long) - Method in class org.apache.arrow.vector.DateMilliVector
-
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, long) - 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.DurationVector
-
Set the element at the given index to the given value.
- set(int, long) - Method in class org.apache.arrow.vector.TimeMicroVector
-
Set the element at the given index to the given value.
- set(int, long) - Method in class org.apache.arrow.vector.TimeNanoVector
-
Set the element at the given index to the given value.
- set(int, long) - Method in class org.apache.arrow.vector.TimeStampVector
-
Set the element at the given index to the given value.
- set(int, long) - Method in class org.apache.arrow.vector.UInt8Vector
-
Set the element at the given index to the given value.
- 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(int, long, 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.DecimalVector
-
Set the element at the given index to the given value.
- set(int, short) - Method in class org.apache.arrow.vector.Float2Vector
-
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, BigDecimal) - 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.DecimalVector
-
Set the element at the given index to the given value.
- set(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
- 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, 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, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Set the variable length element at the specified index to the content in supplied ByteBuffer.
- set(int, ByteBuffer, int, int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Set the variable length element at the specified index to the supplied ByteBuffer.
- set(int, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
-
Set the element at the given index to the given value.
- set(int, ArrowBuf) - Method in class org.apache.arrow.vector.DecimalVector
-
Set the element at the given index to the given value.
- set(int, ArrowBuf) - Method in class org.apache.arrow.vector.DurationVector
-
Set the element at the given index to the given value.
- set(int, ArrowBuf) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
-
Set the element at the given index to the given value.
- set(int, ArrowBuf) - Method in class org.apache.arrow.vector.IntervalDayVector
-
Set the element at the given index to the given value.
- set(int, ArrowBuf) - Method in class org.apache.arrow.vector.IntervalMonthDayNanoVector
-
Set the element at the given index to the given value.
- 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, 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, 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, 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, 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, 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, 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, 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, Float2Holder) - Method in class org.apache.arrow.vector.Float2Vector
-
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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, NullableFloat2Holder) - Method in class org.apache.arrow.vector.Float2Vector
-
Set the element at the given index to the value set in data holder.
- 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Set the variable length element at the specified index to the data buffer supplied in the holder.
- set(int, NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Set the variable length element at the specified index to the data buffer supplied in the 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Set the variable length element at the specified index to the data buffer supplied in the holder.
- set(int, ViewVarCharHolder) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
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, 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(int, Text) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Set the variable length element at the specified index to the content in supplied Text.
- set(String) - Method in class org.apache.arrow.vector.util.Text
-
Set to contain the contents of a string.
- 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(ArrowBuf, long, long) - Method in class org.apache.arrow.vector.util.ReusableByteArray
- 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(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(Text) - Method in class org.apache.arrow.vector.util.Text
-
copy a text.
- SET_DEFAULT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
SET_DEFAULT = 4;
- SET_DEFAULT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
SET_DEFAULT = 4;
- SET_NULL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
SET_NULL = 2;
- SET_NULL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
SET_NULL = 2;
- SET_SESSION_OPTIONS - Static variable in interface org.apache.arrow.flight.FlightConstants
- 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.ComplexWriterImpl
-
Set flag to control the FieldType.nullable property when a writer creates a new vector.
- 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 typeTypes.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 typeTypes.ARRAY
. - setAuthHandler(ClientAuthHandler) - Method in class org.apache.arrow.flight.auth.ClientAuthInterceptor
- 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, 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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, 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.
- 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;
- setBoolValue(boolean) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
bool bool_value = 2;
- 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.
- 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.
- 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
- setBytes(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
This method is used to create a view buffer for a variable width vector.
- setBytes(int, ArrowBuf, int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
This method is used to create a view buffer for a variable width vector.
- 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, 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(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) - 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, 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.
- 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 JDBCResultSet
. - 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.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.
- setCatalog(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The catalog of the destination table to load data into.
- 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.
- setCatalogBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The catalog of the destination table to load data into.
- 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.
- 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.
- 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(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.
- setDoubleValue(double) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
double double_value = 4;
- 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(Timestamp) - 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.FlightEndpoint.Builder
-
Expiration time of this stream.
- setExpirationTime(Timestamp.Builder) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
-
Expiration time for this request.
- setExpirationTime(Instant) - Method in class org.apache.arrow.flight.FlightEndpoint.Builder
-
Set expiration time for the endpoint.
- 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;
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
-
Deprecated.
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- 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) - 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.FlightData.Builder
-
The descriptor of the data.
- setFlightDescriptor(Flight.FlightDescriptor.Builder) - 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.PollInfo.Builder
-
The descriptor the client should use on the next try.
- 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.
- setIfExists(FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- setIfExistsValue(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption if_exists = 2;
- setIfNotExist(FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- setIfNotExistValue(int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
-
.arrow.flight.protocol.sql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption if_not_exist = 1;
- 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.BaseVariableWidthViewVector
-
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(int, int) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
-
Values are modelled after ODBC's SQLGetInfo() function.
- 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(Flight.FlightInfo) - 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.CancelFlightInfoRequest.Builder
-
.arrow.flight.protocol.FlightInfo info = 1;
- setInfo(Flight.FlightInfo.Builder) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
-
The currently available results.
- 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) - 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.BaseVariableWidthViewVector
-
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.BaseLargeRepeatedValueViewVector
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- setInitialCapacity(int) - 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) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.ListVector
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Set the initial record capacity.
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.StructVector
- setInitialCapacity(int) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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.
- setInitialCapacity(int, double) - 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.BaseVariableWidthVector
-
Sets the desired value capacity for the vector.
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Sets the desired value capacity for the vector.
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
-
Specialized version of setInitialCapacity() for ListVector.
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.LargeListVector
-
Specialized version of setInitialCapacity() for ListVector.
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Specialized version of setInitialCapacity() for LargeListViewVector.
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.ListVector
-
Specialized version of setInitialCapacity() for ListVector.
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Specialized version of setInitialCapacity() for ListViewVector.
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- setInitialCapacity(int, double) - Method in class org.apache.arrow.vector.complex.StructVector
- 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.
- setInitialTotalCapacity(int, int) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
-
Specialized version of setInitialTotalCapacity() for LargeListViewVector.
- 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.BaseRepeatedValueViewVector
-
Specialized version of setInitialTotalCapacity() for ListViewVector.
- 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.LargeListViewVector
-
Specialized version of setInitialTotalCapacity() for LargeListViewVector.
- setInitialTotalCapacity(int, int) - Method in class org.apache.arrow.vector.complex.ListVector
-
Specialized version of setInitialTotalCapacity() for ListVector.
- setInitialTotalCapacity(int, int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Specialized version of setInitialTotalCapacity() for ListViewVector.
- 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.
- setInt64Value(long) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
sfixed64 int64_value = 3;
- 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.BaseVariableWidthViewVector
-
Set the index of the 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
- setLastSet(int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Set the index of the last non-null element in the vector.
- 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 class org.apache.arrow.memory.RootAllocator
-
Set the maximum amount of memory that can be allocated in the this Accountant before failing an allocation.
- 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().
- 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.
- setMaxHeaderListSize(int) - Method in class org.apache.arrow.flight.FlightServer.Builder
- setMemory(long, long, byte) - Static method in class org.apache.arrow.memory.util.MemoryUtil
- 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.
- 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.BaseVariableWidthViewVector
-
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.LargeListViewVector
-
Set the element at the given index to 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.ListViewVector
-
Set the element at the given index to null.
- setNull(int) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Set the element at the given index to 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.
- setOffset(int, int) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setOffset(int, int) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Set the offset at the given index.
- setOffset(int, int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Set the offset at the given index.
- setOnCancelHandler(Runnable) - Method in interface org.apache.arrow.flight.FlightProducer.ServerStreamListener
-
Set a callback for when the client cancels a call, i.e.
- setOne(int, int) - Method in class org.apache.arrow.memory.ArrowBuf
-
Deprecated.use
ArrowBuf.setOne(long, long)
instead. - 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 class org.apache.arrow.flight.sql.FlightSqlClient.PreparedStatement
-
Set the
FlightSqlClient.PreparedStatement.parameterBindingRoot
containing the parameter binding from aFlightSqlClient.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(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
-
The serialized substrait.Plan to create a prepared statement for.
- 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) - 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.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.CommandStatementSubstraitPlan.Builder
-
A serialized substrait.Plan
- setPosition(int) - Method in class org.apache.arrow.adapter.avro.consumers.BaseAvroConsumer
- setPosition(int) - Method in interface org.apache.arrow.adapter.avro.consumers.Consumer
-
Set the position to write value into vector.
- setPosition(int) - Method in class org.apache.arrow.adapter.avro.consumers.SkipConsumer
- setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.DateMilliReaderImpl
- setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
- 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.Float2HolderReaderImpl
- 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.NullableFloat2HolderReaderImpl
- 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.NullableViewVarBinaryHolderReaderImpl
- setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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.UnionLargeListViewReader
- setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- 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.UnionListViewReader
- setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- setPosition(int) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- 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(int) - Method in class org.apache.arrow.vector.table.Row
-
Moves this Row to the given 0-based row index.
- setPosition(long) - Method in class org.apache.arrow.vector.ipc.SeekableReadChannel
- 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.
- setPreparedStatementHandle(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
-
Represents a (potentially updated) 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.adapter.avro.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.
- 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.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.Action.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.ActionType.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.BasicAuth.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.CancelFlightInfoResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.Criteria.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.Empty.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightData.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightDescriptor.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightEndpoint.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.FlightInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.HandshakeResponse.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.Location.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.PollInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.PutResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.RenewFlightEndpointRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.Result.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.SchemaResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginSavepointResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionBeginTransactionResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryRequest.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.Builder
-
Deprecated.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionClosePreparedStatementRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedStatementResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionCreatePreparedSubstraitPlanRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCatalogs.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetCrossReference.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetDbSchemas.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetExportedKeys.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetImportedKeys.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetPrimaryKeys.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTableTypes.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetXdbcTypeInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementQuery.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandPreparedStatementUpdate.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementQuery.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementSubstraitPlan.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementUpdate.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutPreparedStatementResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.DoPutUpdateResult.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.SubstraitPlan.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.TicketStatementQuery.Builder
- 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) - 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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[]) - 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[]) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Same as
BaseVariableWidthViewVector.set(int, byte[])
except that it handles the case where index and length of a new element are beyond the existing capacity of the vector. - setSafe(int, byte[]) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
-
Same as
FixedSizeBinaryVector.set(int, byte[])
but reallocates ifindex
is larger than capacity. - setSafe(int, byte[]) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Set the variable length element at the specified index to the supplied byte array, and it handles the case where index and length of a new element are beyond the existing capacity of the vector.
- setSafe(int, byte[], int, int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
- 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, 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, byte[], int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Same as
BaseVariableWidthViewVector.set(int, byte[], int, int)
except that it handles the case where index and length of a new element are beyond the existing capacity of the vector. - setSafe(int, byte[], int, int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Set the variable length element at the specified index to the supplied byte array, and it handles the case where index and length of a new element are beyond the existing capacity.
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.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, 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, byte[]) - Method in class org.apache.arrow.vector.FixedSizeBinaryVector
- 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, 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, 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, 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, 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, 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 capacityBaseFixedWidthVector.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, 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, 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, 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, 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, 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, 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, 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, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Same as
BaseVariableWidthViewVector.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, 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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, int, int, ArrowBuf) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Same as
BaseVariableWidthViewVector.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, 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, 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, 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, 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, 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, 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, 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, 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, int, long, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
-
Same as
Decimal256Vector.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, 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, int, short) - Method in class org.apache.arrow.vector.Float2Vector
-
Same as
Float2Vector.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, 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, 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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, long, ArrowBuf) - Method in class org.apache.arrow.vector.Decimal256Vector
-
Same as
Decimal256Vector.set(int, int, ArrowBuf)
except that it handles the case when index is greater than or equal to existing value capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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, 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, short) - Method in class org.apache.arrow.vector.Float2Vector
-
Same as
Float2Vector.set(int, short)
except that it handles the case when index is greater than or equal to existing value capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseFixedWidthVector
- 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, 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, ByteBuffer, int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Same as
BaseVariableWidthViewVector.set(int, ByteBuffer, int, int)
except that it handles the case where index and length of a new element are beyond the existing capacity of the vector. - setSafe(int, ByteBuffer, int, int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Set the variable length element at the specified index to the supplied ByteBuffer, and it handles the case where index and length of a new element are beyond the existing capacity.
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, DenseUnionHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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 capacityBaseFixedWidthVector.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, Float2Holder) - Method in class org.apache.arrow.vector.Float2Vector
-
Same as
Float2Vector.set(int, Float2Holder)
except that it handles the case when index is greater than or equal to existing value capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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, 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, 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableBitHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableBitHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableDecimal256Holder) - Method in class org.apache.arrow.vector.Decimal256Vector
-
Same as
Decimal256Vector.set(int, NullableDecimalHolder)
except that it handles the case when index is greater than or equal to existing value capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableDecimal256Holder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableDecimalHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableDurationHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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, NullableFixedSizeBinaryHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableFloat2Holder) - Method in class org.apache.arrow.vector.Float2Vector
-
Same as
Float2Vector.set(int, NullableFloat2Holder)
except that it handles the case when index is greater than or equal to existing value capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeStampMicroTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeStampMilliTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeStampNanoTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableTimeStampSecTZHolder, ArrowType) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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 capacityBaseFixedWidthVector.getValueCapacity()
. - setSafe(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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, NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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, NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Same as
ViewVarBinaryVector.set(int, NullableViewVarBinaryHolder)
except that it handles the case where index and length of a new element are beyond the existing capacity of the vector. - setSafe(int, NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.DenseUnionVector
- setSafe(int, NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.UnionVector
- setSafe(int, NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Same as
ViewVarCharVector.set(int, NullableViewVarCharHolder)
except that it handles the case where index and length of a new element are beyond the existing capacity of the vector. - 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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.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 capacityBaseFixedWidthVector.getValueCapacity()
. - 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, 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, 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, ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.ViewVarBinaryVector
-
Same as
ViewVarBinaryVector.set(int, ViewVarBinaryHolder)
except that it handles the case where index and length of a new element are beyond the existing capacity of the vector. - setSafe(int, ViewVarCharHolder) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Same as
ViewVarCharVector.set(int, ViewVarCharHolder)
except that it handles the case where index and length of a 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, 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. - setSafe(int, Text) - Method in class org.apache.arrow.vector.ViewVarCharVector
-
Same as
ViewVarCharVector.set(int, NullableViewVarCharHolder)
except that it handles the case where index and length of a 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.Float2Vector
- 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.
- setSafeWithPossibleTruncate(int, float) - Method in class org.apache.arrow.vector.Float2Vector
-
Same as
Float2Vector.setWithPossibleTruncate(int, float)
except that it handles the case when index is greater than or equal to existing value capacityBaseFixedWidthVector.getValueCapacity()
. - setSafeWithPossibleTruncate(int, int, float) - Method in class org.apache.arrow.vector.Float2Vector
-
Same as
Float2Vector.set(int, int, short)
except that it handles the case when index is greater than or equal to current value capacity of the vector. - 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(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(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The db_schema of the destination table to load data into.
- setSchemaBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The db_schema of the destination table to load data into.
- setSchemaMetadata(Map<String, String>) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
-
Set metadata for schema.
- setSessionOption(String, SessionOptionValue) - Method in class org.apache.arrow.flight.ServerSessionMiddleware.Session
-
Set session option by name to given value.
- setSessionOptions(SetSessionOptionsRequest, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Set server session option(s) by name/value.
- setSessionOptions(SetSessionOptionsRequest, CallOption...) - Method in class org.apache.arrow.flight.sql.FlightSqlClient
- setSessionOptions(SetSessionOptionsRequest, FlightProducer.CallContext, FlightProducer.StreamListener<SetSessionOptionsResult>) - Method in interface org.apache.arrow.flight.sql.FlightSqlProducer
-
Set server session options(s).
- SetSessionOptionsRequest - Class in org.apache.arrow.flight
-
A request to set option(s) in an existing or implicitly-created server session.
- SetSessionOptionsRequest(Map<String, SessionOptionValue>) - Constructor for class org.apache.arrow.flight.SetSessionOptionsRequest
- SetSessionOptionsResult - Class in org.apache.arrow.flight
-
The result of attempting to set a set of session options.
- SetSessionOptionsResult(Map<String, SetSessionOptionsResult.Error>) - Constructor for class org.apache.arrow.flight.SetSessionOptionsResult
- SetSessionOptionsResult.Error - Class in org.apache.arrow.flight
-
Per-option extensible error response container.
- SetSessionOptionsResult.ErrorValue - Enum in org.apache.arrow.flight
-
Error status value for per-option errors.
- SetSessionOptionsResultListener - Class in org.apache.arrow.flight.sql
-
Typed StreamListener for setSessionOptions.
- 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.
- setSize(int, int) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Set the size at the given index.
- setSize(int, int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Set the size at the given index.
- setSkipFieldNames(Set<String>) - Method in class org.apache.arrow.adapter.avro.AvroToArrowConfigBuilder
- 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;
- setStatus(Flight.CloseSessionResult.Status) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.Builder
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- setStatusValue(int) - 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.CloseSessionResult.Builder
-
.arrow.flight.protocol.CloseSessionResult.Status status = 1;
- setStringListValue(Flight.SessionOptionValue.StringListValue) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- setStringListValue(Flight.SessionOptionValue.StringListValue.Builder) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
.arrow.flight.protocol.SessionOptionValue.StringListValue string_list_value = 5;
- setStringValue(String) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
string string_value = 1;
- setStringValueBytes(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.Builder
-
string string_value = 1;
- 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.
- setTable(String) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The table to load data into.
- 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.
- setTableBytes(ByteString) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The table to load data into.
- setTableDefinitionOptions(FlightSql.CommandStatementIngest.TableDefinitionOptions) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- setTableDefinitionOptions(FlightSql.CommandStatementIngest.TableDefinitionOptions.Builder) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
The behavior for handling the table definition.
- 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.avro.AvroToArrowConfigBuilder
- setTargetBatchSize(int) - Method in class org.apache.arrow.adapter.jdbc.JdbcToArrowConfigBuilder
-
Set the target number of rows to convert at once.
- setTemporary(boolean) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.Builder
-
Store ingested data in a temporary table.
- setTicket(ByteString) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.Builder
-
bytes ticket = 1;
- 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.
- 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.CommandStatementIngest.Builder
-
Perform the ingestion as part of this transaction.
- 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).
- setType(int, Types.MinorType) - Method in class org.apache.arrow.vector.complex.UnionVector
- 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;
- 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
- 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.CloseSessionRequest.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult.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.GetSessionOptionsRequest.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult.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.SessionOptionValue.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.impl.Flight.Ticket.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.CommandStatementIngest.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.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.DoPutPreparedStatementResult.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.
- setValidity(int, int) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Set the validity at the given index.
- setValidity(int, int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Set the validity at the given index.
- 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
- setValue(Flight.SetSessionOptionsResult.ErrorValue) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- 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.BaseVariableWidthViewVector
-
Sets the value count for the vector.
- setValueCount(int) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- 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.BaseRepeatedValueViewVector
- 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.UnionLargeListViewWriter
- setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- setValueCount(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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.LargeListViewVector
-
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.ListViewVector
- setValueCount(int) - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- setValueCount(int) - Method in class org.apache.arrow.vector.complex.RunEndEncodedVector
-
Set number of values in the vector.
- 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.
- setValueLengthSafe(int, int) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Sets the value length for an element.
- setValueLengthSafe(int, int) - Method in interface org.apache.arrow.vector.VariableWidthFieldVector
-
Sets the value length for an element.
- setValues(int, String) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue.Builder
-
repeated string values = 1;
- setValueValue(int) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error.Builder
-
.arrow.flight.protocol.SetSessionOptionsResult.ErrorValue value = 1;
- 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.
- setWithPossibleTruncate(int, double) - Method in class org.apache.arrow.vector.Float2Vector
- 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, float) - Method in class org.apache.arrow.vector.Float2Vector
-
Set the element at the given index to the given value.
- setWithPossibleTruncate(int, int, float) - Method in class org.apache.arrow.vector.Float2Vector
-
Store the given value at a particular position in the vector.
- 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, 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
- setWriter(ValueVector) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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(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.SparseTensor
- 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() - Method in class org.apache.arrow.flatbuf.Tensor
- shapeVector(TensorDim.Vector) - Method in class org.apache.arrow.flatbuf.SparseTensor
- 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 - Enum constant in enum org.apache.arrow.vector.complex.impl.PromotableWriter.State
- SINGLE - Enum constant in enum org.apache.arrow.vector.types.FloatingPointPrecision
-
32-bit (i.e.
- 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
-
FieldReader
for a singleNonNullableStructVector
. - 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.NullableStructReaderImpl
- 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.Float2HolderReaderImpl
- 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.NullableFloat2HolderReaderImpl
- 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.NullableViewVarBinaryHolderReaderImpl
- size() - Method in class org.apache.arrow.vector.complex.impl.NullableViewVarCharHolderReaderImpl
- 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.UnionLargeListViewReader
- size() - Method in class org.apache.arrow.vector.complex.impl.UnionListReader
- size() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewReader
- 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 class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- size() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- 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 - Enum constant in enum org.apache.arrow.vector.BufferLayout.BufferType
- SIZE_OF_UNCOMPRESSED_LENGTH - Static variable in class org.apache.arrow.vector.compression.CompressionUtil
- SIZE_WIDTH - Static variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- SIZE_WIDTH - Static variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- sizeAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- sizeAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- sizeBuffer - Variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- sizeBuffer - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- sizeBuffer() - Static method in class org.apache.arrow.vector.BufferLayout
- sizeOfValueBuffer() - Method in class org.apache.arrow.vector.BaseLargeVariableWidthVector
- sizeOfValueBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthVector
- sizeOfValueBuffer() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
- sizeOfValueBuffer() - Method in interface org.apache.arrow.vector.VariableWidthVector
-
Provide the number of bytes contained in the valueBuffer.
- sizeOfViewBufferElements() - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Get the size (number of bytes) of underlying elements in the view buffer.
- 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.adapter.avro.consumers
-
Consumer which skip (throw away) data from the decoder.
- SkipConsumer(SkipFunction) - Constructor for class org.apache.arrow.adapter.avro.consumers.SkipConsumer
- SkipFunction - Interface in org.apache.arrow.adapter.avro.consumers
-
Adapter function to skip (throw away) data from the decoder.
- skippable() - Method in interface org.apache.arrow.adapter.avro.consumers.Consumer
-
Indicates whether the consumer is type of
SkipConsumer
. - skippable() - Method in class org.apache.arrow.adapter.avro.consumers.SkipConsumer
- slice() - Method in class org.apache.arrow.memory.ArrowBuf
-
Returns a slice of only the readable bytes in the buffer.
- slice(int) - Method in class org.apache.arrow.vector.table.Table
-
Slice this table from desired index.
- 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.table.Table
-
Slice this table at desired index and length.
- slice(int, int) - Method in class org.apache.arrow.vector.VectorSchemaRoot
-
Slice this root at desired index and length.
- slice(long, long) - Method in class org.apache.arrow.memory.ArrowBuf
-
Returns a slice (view) starting at
index
with the givenlength
. - smallInt() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- smallInt() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- smallInt(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- smallInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- smallInt(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- SMALLINT - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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 - Enum constant in enum org.apache.arrow.vector.types.UnionMode
-
Each child vector is the same length as the overall vector, and there is one 8-bit integer buffer to indicate the index of a child vector to use at any given position.
- 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 - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
- SparseMatrixIndexCSX() - Constructor for class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
- SparseMatrixIndexCSX.Vector - Class in org.apache.arrow.flatbuf
- SparseTensor - Class in org.apache.arrow.flatbuf
- SparseTensor - Static variable in class org.apache.arrow.flatbuf.MessageHeader
- 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 - Class in org.apache.arrow.flatbuf
-
---------------------------------------------------------------------- EXPERIMENTAL: Data structures for sparse tensors Coordinate (COO) format of sparse tensor index.
- SparseTensorIndexCOO - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
- SparseTensorIndexCOO() - Constructor for class org.apache.arrow.flatbuf.SparseTensorIndexCOO
- SparseTensorIndexCOO.Vector - Class in org.apache.arrow.flatbuf
- SparseTensorIndexCSF - Class in org.apache.arrow.flatbuf
-
Compressed Sparse Fiber (CSF) sparse tensor index.
- SparseTensorIndexCSF - Static variable in class org.apache.arrow.flatbuf.SparseTensorIndex
- 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, 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.
- 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, BaseVariableWidthViewVector) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Slice this vector at desired index and length and transfer the corresponding data to the target vector.
- SQL_ALL_TABLES_ARE_SELECTABLE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether all tables are selectable.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported ANSI92 SQL grammar level.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether this database supports batch updates.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
-
SQL_CASE_SENSITIVITY_CASE_INSENSITIVE = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
-
SQL_CASE_SENSITIVITY_LOWERCASE = 3;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
-
SQL_CASE_SENSITIVITY_UNKNOWN = 0;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
-
SQL_CASE_SENSITIVITY_UPPERCASE = 2;
- 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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string with the preferred term for "catalog".
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported actions for a SQL schema.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_BIGINT = 0;
- SQL_CONVERT_BIGINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_BIGINT = 0;
- SQL_CONVERT_BINARY - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_BINARY = 1;
- SQL_CONVERT_BINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_BINARY = 1;
- SQL_CONVERT_BIT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_BIT = 2;
- SQL_CONVERT_BIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_BIT = 2;
- SQL_CONVERT_CHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_CHAR = 3;
- SQL_CONVERT_CHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_CHAR = 3;
- SQL_CONVERT_DATE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_DATE = 4;
- SQL_CONVERT_DATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_DATE = 4;
- SQL_CONVERT_DECIMAL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_DECIMAL = 5;
- SQL_CONVERT_DECIMAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_DECIMAL = 5;
- SQL_CONVERT_FLOAT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_FLOAT = 6;
- SQL_CONVERT_FLOAT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_FLOAT = 6;
- SQL_CONVERT_INTEGER - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_INTEGER = 7;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_INTERVAL_DAY_TIME = 8;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_INTERVAL_YEAR_MONTH = 9;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_LONGVARBINARY = 10;
- SQL_CONVERT_LONGVARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_LONGVARBINARY = 10;
- SQL_CONVERT_LONGVARCHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_LONGVARCHAR = 11;
- SQL_CONVERT_LONGVARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_LONGVARCHAR = 11;
- SQL_CONVERT_NUMERIC - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_NUMERIC = 12;
- SQL_CONVERT_NUMERIC_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_NUMERIC = 12;
- SQL_CONVERT_REAL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_REAL = 13;
- SQL_CONVERT_REAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_REAL = 13;
- SQL_CONVERT_SMALLINT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_SMALLINT = 14;
- SQL_CONVERT_SMALLINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_SMALLINT = 14;
- SQL_CONVERT_TIME - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_TIME = 15;
- SQL_CONVERT_TIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_TIME = 15;
- SQL_CONVERT_TIMESTAMP - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_TIMESTAMP = 16;
- SQL_CONVERT_TIMESTAMP_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_TIMESTAMP = 16;
- SQL_CONVERT_TINYINT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_TINYINT = 17;
- SQL_CONVERT_TINYINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_TINYINT = 17;
- SQL_CONVERT_VARBINARY - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_VARBINARY = 18;
- SQL_CONVERT_VARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_VARBINARY = 18;
- SQL_CONVERT_VARCHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_VARCHAR = 19;
- SQL_CONVERT_VARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
SQL_CONVERT_VARCHAR = 19;
- SQL_CORE_GRAMMAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
SQL_CORE_GRAMMAR = 1;
- SQL_CORE_GRAMMAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
SQL_CORE_GRAMMAR = 1;
- SQL_CORRELATED_SUBQUERIES_SUPPORTED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether correlated subqueries are supported.
- 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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
-
SQL_DATA_DEFINITION_TRANSACTIONS = 1;
- 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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
-
SQL_DATA_MANIPULATION_TRANSACTIONS = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string list with values of the supported datetime functions.
- 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Indicates whether the Flight SQL Server supports CREATE and DROP of tables.
- 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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
-
SQL_ELEMENT_IN_INDEX_DEFINITIONS = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
-
SQL_ELEMENT_IN_PRIVILEGE_DEFINITIONS = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
-
SQL_ELEMENT_IN_PROCEDURE_CALLS = 0;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
SQL_EXTENDED_GRAMMAR = 2;
- SQL_EXTENDED_GRAMMAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
SQL_EXTENDED_GRAMMAR = 2;
- SQL_EXTRA_NAME_CHARACTERS - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
-
SQL_FULL_OUTER_JOINS = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
-
SQL_GROUP_BY_BEYOND_SELECT = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
-
SQL_GROUP_BY_UNRELATED = 0;
- 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
-
SQL_JOINS_UNSUPPORTED = 0;
- SQL_JOINS_UNSUPPORTED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
-
SQL_JOINS_UNSUPPORTED = 0;
- SQL_KEYWORDS - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string list with values of the supported keywords.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
-
SQL_LIMITED_OUTER_JOINS = 1;
- 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a int64 value representing the maximum number of concurrent connections possible.
- 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_ROW_SIZE_INCLUDES_BLOBS - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
SQL_MINIMUM_GRAMMAR = 0;
- SQL_MINIMUM_GRAMMAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
SQL_MINIMUM_GRAMMAR = 0;
- SQL_NAMED_PARAMETERS_SUPPORTED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether named parameters are supported in callable statements.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the null ordering.
- 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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
-
SQL_NULLS_SORTED_AT_END = 3;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
-
SQL_NULLS_SORTED_AT_START = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
-
SQL_NULLS_SORTED_HIGH = 0;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
-
SQL_NULLS_SORTED_LOW = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string list with values of the supported numeric functions.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the support level for SQL OUTER JOINs.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
-
SQL_POSITIONED_DELETE = 0;
- SQL_POSITIONED_DELETE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
-
SQL_POSITIONED_DELETE = 0;
- SQL_POSITIONED_UPDATE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
-
SQL_POSITIONED_UPDATE = 1;
- SQL_POSITIONED_UPDATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
-
SQL_POSITIONED_UPDATE = 1;
- SQL_PROCEDURE_TERM - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string with the preferred term for "procedure".
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a int32 describing the case sensitivity of quoted identifiers.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
-
SQL_RESULT_SET_CONCURRENCY_READ_ONLY = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
-
SQL_RESULT_SET_CONCURRENCY_UNSPECIFIED = 0;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
-
SQL_RESULT_SET_CONCURRENCY_UPDATABLE = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
-
SQL_RESULT_SET_TYPE_FORWARD_ONLY = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
-
SQL_RESULT_SET_TYPE_SCROLL_INSENSITIVE = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
-
SQL_RESULT_SET_TYPE_SCROLL_SENSITIVE = 3;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
-
SQL_RESULT_SET_TYPE_UNSPECIFIED = 0;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether this database supports savepoints.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string with the preferred term for "schema".
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported actions for a SQL 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the UTF-8 string that can be used to escape wildcard characters.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether SELECT FOR UPDATE statements are supported.
- 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string list with values of the supported string functions.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
-
SQL_SUBQUERIES_IN_COMPARISONS = 0;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
-
SQL_SUBQUERIES_IN_EXISTS = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
-
SQL_SUBQUERIES_IN_INS = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
-
SQL_SUBQUERIES_IN_QUANTIFIEDS = 3;
- 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported SQL grammar level as per the ODBC specification.
- 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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported SQL positioned 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves an int32 bitmask value representing the supported result set types.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported SQL subqueries.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
-
Unknown/not indicated/no support
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
-
Transactions and savepoints
- SQL_SUPPORTED_TRANSACTION_SAVEPOINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
-
Transactions and savepoints
- SQL_SUPPORTED_TRANSACTION_TRANSACTION - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
-
Transactions, but not 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported transactions isolation levels.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves the supported SQL UNIONs.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether column aliasing is supported.
- 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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant 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_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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a UTF-8 string list with values of the supported system functions.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
SQL_TRANSACTION_NONE = 0;
- SQL_TRANSACTION_NONE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
SQL_TRANSACTION_NONE = 0;
- SQL_TRANSACTION_READ_COMMITTED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
SQL_TRANSACTION_READ_COMMITTED = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
SQL_TRANSACTION_READ_UNCOMMITTED = 1;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
SQL_TRANSACTION_REPEATABLE_READ = 3;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
SQL_TRANSACTION_SERIALIZABLE = 4;
- SQL_TRANSACTION_SERIALIZABLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
SQL_TRANSACTION_SERIALIZABLE = 4;
- SQL_TRANSACTION_UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
-
SQL_TRANSACTION_UNSPECIFIED = 0;
- SQL_TRANSACTION_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
-
SQL_TRANSACTION_UNSPECIFIED = 0;
- SQL_TRANSACTIONS_SUPPORTED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Retrieves a boolean value indicating whether transactions are supported.
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
-
SQL_UNION = 0;
- SQL_UNION_ALL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
-
SQL_UNION_ALL = 1;
- 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
-
Auxiliary class meant to facilitate the implementation of
FlightSqlProducer.getStreamSqlInfo(org.apache.arrow.flight.sql.impl.FlightSql.CommandGetSqlInfo, org.apache.arrow.flight.FlightProducer.CallContext, org.apache.arrow.flight.FlightProducer.ServerStreamListener)
. - SqlInfoBuilder() - Constructor for class org.apache.arrow.flight.sql.SqlInfoBuilder
- SqlInfoOptionsUtils - Class in org.apache.arrow.flight.sql.util
-
Utility class for
FlightSql.SqlInfo
andFlightSqlClient.getSqlInfo(org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo...)
option parsing. - 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. - 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. - 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 - 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.NullableViewVarBinaryHolder
- start - Variable in class org.apache.arrow.vector.holders.NullableViewVarCharHolder
- 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 - Variable in class org.apache.arrow.vector.holders.ViewVarBinaryHolder
- start - Variable in class org.apache.arrow.vector.holders.ViewVarCharHolder
- start() - Method in class org.apache.arrow.flight.FlightServer
-
Start the server.
- start() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- start() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- start() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- start() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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() - 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(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
. - 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.ComplexWriterImpl
- startEntry() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- startEntry() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
-
Start a map entry that should be followed by calls to
UnionMapWriter.key()
andUnionMapWriter.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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- startList() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- startList() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- startList() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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
- startList(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.List
- startListView() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- startListView() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- startListView() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- startListView() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- startListView() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- startListView() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- startListView() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- startListView(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.ListView
- startMap() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- startMap() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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
- startMap(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Map
- startMessage(FlatBufferBuilder) - Static method in class org.apache.arrow.flatbuf.Message
- startNewValue(int) - Method in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
-
Start a new value at the given index.
- 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.BaseRepeatedValueViewVector
-
Start a new value at the given index.
- startNewValue(int) - Method in class org.apache.arrow.vector.complex.FixedSizeListVector
-
Start a new value in the list vector.
- startNewValue(int) - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Start new value in the ListView vector.
- startNewValue(int) - Method in class org.apache.arrow.vector.complex.ListVector
-
Start a new value in the list vector.
- startNewValue(int) - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Start new value in the ListView vector.
- startNewValue(long) - Method in class org.apache.arrow.vector.complex.LargeListVector
-
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, FlightClient.PutListener, CallOption...) - Method in class org.apache.arrow.flight.FlightClient
-
Create or append a descriptor with another stream.
- 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.
- 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
- state - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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
- STATUS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- StatusUtils - Class in org.apache.arrow.flight.grpc
-
Utilities to adapt gRPC and Flight status objects.
- storageType() - Method in class org.apache.arrow.vector.extension.OpaqueType
- storageType() - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ExtensionType
-
The on-wire type for this user-defined type.
- 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
- STRING_LIST_VALUE - Enum constant in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- STRING_LIST_VALUE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- STRING_VALUE - Enum constant in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
- STRING_VALUE_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- struct - Variable in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
- struct() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- struct() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- struct() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- struct() - Method in class org.apache.arrow.vector.complex.impl.NullReader
- struct() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- struct() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- struct() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- struct() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- struct() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- struct() - 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.UnionViewWriter
- struct() - 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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(String) - Method in class org.apache.arrow.vector.complex.impl.NullReader
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
-
Creates a new writer for a struct with the given name.
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- struct(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Struct() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Struct
- STRUCT - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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_ - Static variable in class org.apache.arrow.flatbuf.Type
- Struct_() - Constructor for class org.apache.arrow.flatbuf.Struct_
- Struct_.Vector - Class in org.apache.arrow.flatbuf
- StructOrListWriterImpl - Class in org.apache.arrow.vector.complex.impl
-
Concrete implementation of
BaseWriter.StructOrListWriter
. - StructOrListWriterImpl(BaseWriter.ListWriter) - Constructor for class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
-
Constructs a new instance using a
BaseWriter.ListWriter
(instead of aBaseWriter.StructWriter
). - StructOrListWriterImpl(BaseWriter.StructWriter) - Constructor for class org.apache.arrow.vector.complex.impl.StructOrListWriterImpl
-
Constructs a new instance using a
BaseWriter.StructWriter
(instead of anBaseWriter.ListWriter
). - 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
. - structWriter - Variable in class org.apache.arrow.vector.complex.impl.UnionWriter
- submit(Runnable) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
- submit(Runnable, T) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
- submit(Callable<T>) - Method in class org.apache.arrow.flight.grpc.ContextPropagatingExecutorService
- SubstraitPlan(byte[], String) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.SubstraitPlan
- subtractFrom(Temporal) - Method in class org.apache.arrow.vector.PeriodDuration
- SUCCESS - Enum constant in enum org.apache.arrow.memory.AllocationOutcome.Status
-
Allocation succeeded.
- supportsDirectRead() - Method in class org.apache.arrow.vector.complex.AbstractContainerVector
- supportsDirectRead() - Method in class org.apache.arrow.vector.complex.NonNullableStructVector
- 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
- 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_DEFINITION_OPTIONS_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- TABLE_EXISTS_OPTION_APPEND - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Append to the table if it already exists
- TABLE_EXISTS_OPTION_APPEND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Append to the table if it already exists
- TABLE_EXISTS_OPTION_FAIL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Fail if the table already exists
- TABLE_EXISTS_OPTION_FAIL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Fail if the table already exists
- TABLE_EXISTS_OPTION_REPLACE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Drop and recreate the table if it already exists
- TABLE_EXISTS_OPTION_REPLACE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Drop and recreate the table if it already exists
- TABLE_EXISTS_OPTION_UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Do not use.
- TABLE_EXISTS_OPTION_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Do not use.
- 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_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- TABLE_NAME_FILTER_PATTERN_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandGetTables
- TABLE_NOT_EXIST_OPTION_CREATE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Create the table if it does not exist
- TABLE_NOT_EXIST_OPTION_CREATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Create the table if it does not exist
- TABLE_NOT_EXIST_OPTION_FAIL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Fail if the table does not exist
- TABLE_NOT_EXIST_OPTION_FAIL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Fail if the table does not exist
- TABLE_NOT_EXIST_OPTION_UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Do not use.
- TABLE_NOT_EXIST_OPTION_UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Do not use.
- 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.
- TEMPORARY_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- Tensor - Class in org.apache.arrow.flatbuf
- Tensor - Static variable in class org.apache.arrow.flatbuf.MessageHeader
- 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
- 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(byte[]) - Constructor for class org.apache.arrow.vector.util.Text
-
Construct from a byte array.
- 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.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
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Time - Static variable in class org.apache.arrow.flatbuf.Type
- Time() - Constructor for class org.apache.arrow.flatbuf.Time
- 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(TimeMilliVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time32Binder
- Time32Binder(TimeMilliVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time32Binder
- Time32Binder(TimeSecVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time32Binder
- Time32Binder(TimeSecVector, 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(TimeMicroVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time64Binder
- Time64Binder(TimeNanoVector) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time64Binder
- Time64Binder(TimeNanoVector, int) - Constructor for class org.apache.arrow.adapter.jdbc.binder.Time64Binder
- 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 - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The operation timed out.
- TIMED_OUT - Static variable in class org.apache.arrow.flight.CallStatus
- timeFormat - Static variable in class org.apache.arrow.vector.util.DateUtility
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeMicro(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeMicro(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMEMICRO - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeMilli(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeMilli(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMEMILLI - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeNano() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeNano(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeNano(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMENANO - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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
- TIMEOUT - Enum constant in enum org.apache.arrow.flight.BackpressureStrategy.WaitResult
-
Timed out waiting for the listener to change state.
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeSec() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeSec(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeSec(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESEC - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Timestamp - Static variable in class org.apache.arrow.flatbuf.Type
- Timestamp() - Constructor for class org.apache.arrow.flatbuf.Timestamp
- Timestamp(TimeUnit, String) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Timestamp
- Timestamp.Vector - Class in org.apache.arrow.flatbuf
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeStampMicro() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMicro(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMicro(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampMicro(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPMICRO - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- timeStampMicroTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampMicroTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMicroTZ(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) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMicroTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMicroTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampMicroTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPMICROTZ - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeStampMilli() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMilli(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMilli(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampMilli(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPMILLI - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- timeStampMilliTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampMilliTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMilliTZ(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) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMilliTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampMilliTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampMilliTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPMILLITZ - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeStampNano() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampNano(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampNano(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampNano(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPNANO - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- timeStampNanoTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampNanoTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampNanoTZ(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) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampNanoTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampNanoTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampNanoTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPNANOTZ - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- timeStampSec() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampSec(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampSec(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampSec(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPSEC - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- timeStampSecTZ() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampSecTZ() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampSecTZ(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) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampSecTZ(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- timeStampSecTZ(String, String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- timeStampSecTZ(String, String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TIMESTAMPSECTZ - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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 - 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
- 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".
- timezoneAsByteBuffer() - Method in class org.apache.arrow.flatbuf.Timestamp
- timezoneInByteBuffer(ByteBuffer) - Method in class org.apache.arrow.flatbuf.Timestamp
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- tinyInt() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- tinyInt(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- tinyInt(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- tinyInt(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- TINYINT - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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.CloseSessionRequest
- toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue.StringListValue
- toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- toBuilder() - Method in class org.apache.arrow.flight.impl.Flight.Ticket
- 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.CommandStatementIngest.TableDefinitionOptions
- toBuilder() - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- 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.DoPutPreparedStatementResult
- 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. - 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
- toFloat(short) - Static method in class org.apache.arrow.memory.util.Float16
-
Converts the specified half-precision float value into a single-precision float value.
- toFloat16(float) - Static method in class org.apache.arrow.memory.util.Float16
-
Converts the specified single-precision float value into a half-precision float value.
- toFloatString(short) - Static method in class org.apache.arrow.memory.util.Float16
-
Returns a string representation of the specified half-precision float value.
- toGrpcException(Throwable) - Static method in class org.apache.arrow.flight.grpc.StatusUtils
-
Convert arbitrary exceptions to a
StatusRuntimeException
orStatusException
. - 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
. - toISO8601IntervalString() - Method in class org.apache.arrow.vector.PeriodDuration
-
Format this PeriodDuration as an ISO-8601 interval.
- 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(Iterable<T>) - Static method in class org.apache.arrow.util.Collections2
-
Converts the iterable into a new
List
. - toList(Iterator<T>) - Static method in class org.apache.arrow.util.Collections2
-
Creates a
List
from the elements remaining in iterator. - 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.
- toProtocol() - Method in enum org.apache.arrow.flight.CloseSessionResult.Status
- 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.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.RootAllocator
- toString() - Method in class org.apache.arrow.memory.util.StackTrace
- 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.AbstractContainerVector
-
Representation of vector suitable for debugging.
- toString() - Method in class org.apache.arrow.vector.complex.AbstractStructVector
- toString() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- 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.extension.OpaqueType
- 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.Float2Holder
-
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.NullableFloat2Holder
-
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.NullableViewVarBinaryHolder
-
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.NullableViewVarCharHolder
-
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.holders.ViewVarBinaryHolder
-
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.ViewVarCharHolder
-
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.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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.ArrowType.Utf8View
- 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
- toString(Iterator<?>) - Static method in class org.apache.arrow.util.Collections2
-
Creates a human readable string from the remaining elements in iterator.
- 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
- 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 class org.apache.arrow.memory.RootAllocator
-
Provide a verbose string of the current allocator state.
- toVerboseString() - Method in interface org.apache.arrow.memory.BufferAllocator
-
Return a verbose string describing this allocator.
- toViewWriter() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
-
Convert the writer to a PromotableViewWriter.
- toViewWriter() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
-
Convert the UnionWriter to a UnionViewWriter.
- Transaction(byte[]) - Constructor for class org.apache.arrow.flight.sql.FlightSqlClient.Transaction
- 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.CommandStatementIngest
- 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.
- transferTo(BaseVariableWidthViewVector) - Method in class org.apache.arrow.vector.BaseVariableWidthViewVector
-
Transfer this vector's data to another vector.
- 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 - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- 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 - Enum constant in enum org.apache.arrow.vector.BufferLayout.BufferType
- 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.BinaryView
- 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.LargeListView
- 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.ListView
- 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.RunEndEncoded
- 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_TYPE - Static variable in class org.apache.arrow.vector.types.pojo.ArrowType.Utf8View
- 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.Float2Vector
- 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 - Variable in class org.apache.arrow.vector.complex.UnionVector
- typeBuffer() - Static method in class org.apache.arrow.vector.BufferLayout
- 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(boolean, BufferLayout...) - Constructor for class org.apache.arrow.vector.TypeLayout
- TypeLayout(List<BufferLayout>) - Constructor for class org.apache.arrow.vector.TypeLayout
- TypeLayout(List<BufferLayout>, boolean) - Constructor for class org.apache.arrow.vector.TypeLayout
-
Constructs a new
TypeLayout
. - TypeLayout(BufferLayout...) - Constructor for class org.apache.arrow.vector.TypeLayout
- typeName() - Method in class org.apache.arrow.vector.extension.OpaqueType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- uInt1() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt1(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt1(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- uInt1(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- UINT1 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- uInt2() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt2(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt2(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- uInt2(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- UINT2 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- uInt4() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt4(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt4(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- uInt4(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- UINT4 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- uInt8() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- uInt8(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- uInt8(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- uInt8(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- UINT8 - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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 - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The client was not authenticated.
- UNAUTHENTICATED - Static variable in class org.apache.arrow.flight.CallStatus
- UNAUTHORIZED - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The client did not have permission to make the call.
- UNAUTHORIZED - Static variable in class org.apache.arrow.flight.CallStatus
- UNAVAILABLE - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The server cannot currently handle the request.
- UNAVAILABLE - Static variable in class org.apache.arrow.flight.CallStatus
- UNIMPLEMENTED - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
The requested operation is not implemented.
- UNIMPLEMENTED - Static variable in class org.apache.arrow.flight.CallStatus
- 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Union - Static variable in class org.apache.arrow.flatbuf.Type
- Union() - Constructor for class org.apache.arrow.flatbuf.Union
- Union(UnionMode, int[]) - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Union
- UNION - Enum constant in enum org.apache.arrow.vector.complex.impl.PromotableWriter.State
- UNION - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- Union.Vector - Class in org.apache.arrow.flatbuf
- 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, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- UnionFixedSizeListWriter(FixedSizeListVector, NullableStructWriterFactory) - 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
- UnionLargeListViewReader - Class in org.apache.arrow.vector.complex.impl
-
FieldReader
for largeListView of union types. - UnionLargeListViewReader(LargeListViewVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListViewReader
-
Constructor for UnionLargeListViewReader.
- UnionLargeListViewWriter - Class in org.apache.arrow.vector.complex.impl
- UnionLargeListViewWriter(LargeListViewVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- UnionLargeListViewWriter(LargeListViewVector, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- UnionLargeListViewWriter(LargeListViewVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- UnionLargeListWriter - Class in org.apache.arrow.vector.complex.impl
- UnionLargeListWriter(LargeListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- UnionLargeListWriter(LargeListVector, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- UnionLargeListWriter(LargeListVector, NullableStructWriterFactory) - 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
- UnionListViewReader - Class in org.apache.arrow.vector.complex.impl
-
FieldReader
for listview of union types. - UnionListViewReader(ListViewVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListViewReader
-
Constructor for UnionListViewReader.
- UnionListViewWriter - Class in org.apache.arrow.vector.complex.impl
- UnionListViewWriter(ListViewVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- UnionListViewWriter(ListViewVector, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- UnionListViewWriter(ListViewVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- UnionListWriter - Class in org.apache.arrow.vector.complex.impl
- UnionListWriter(ListVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListWriter
- UnionListWriter(ListVector, AbstractFieldWriter) - Constructor for class org.apache.arrow.vector.complex.impl.UnionListWriter
- UnionListWriter(ListVector, NullableStructWriterFactory) - 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 - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- UnionVector - Class in org.apache.arrow.vector.complex
- UnionVector(String, BufferAllocator, FieldType, CallBack) - Constructor for class org.apache.arrow.vector.complex.UnionVector
- UnionViewWriter - Class in org.apache.arrow.vector.complex.impl
- UnionViewWriter(UnionVector) - Constructor for class org.apache.arrow.vector.complex.impl.UnionViewWriter
- UnionViewWriter(UnionVector, NullableStructWriterFactory) - Constructor for class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 - Variable in class org.apache.arrow.vector.holders.DurationHolder
- unit - Variable in class org.apache.arrow.vector.holders.NullableDurationHolder
- 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
- Unknown - Enum constant in enum org.apache.arrow.memory.DefaultAllocationManagerOption.AllocationManagerType
-
Unknown type.
- UNKNOWN - Enum constant in enum org.apache.arrow.flight.FlightStatusCode
-
An unknown error occurred.
- UNKNOWN - Enum constant in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
-
Protobuf pattern, not used.
- 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. - UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.impl.Flight.CancelStatus
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
-
Deprecated.
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
- UNRECOGNIZED - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
- unregister(ArrowType.ExtensionType) - Static method in class org.apache.arrow.vector.types.pojo.ExtensionTypeRegistry
- Unsafe - Enum constant in enum org.apache.arrow.memory.DefaultAllocationManagerOption.AllocationManagerType
-
Unsafe based allocation manager.
- UnsafeAllocationManager - Class in org.apache.arrow.memory.unsafe
-
Allocation manager based on unsafe API.
- 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 between0
and2^64 - 1
inclusive. - UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.CancelStatus
-
The cancellation status is unknown.
- UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.CloseSessionResult.Status
-
The session close status is unknown.
- UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
Protobuf deserialization fallback value: The session close status is unknown or not recognized.
- UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
Protobuf deserialization fallback value: The status is unknown or unrecognized.
- UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.SetSessionOptionsResult.ErrorValue
-
The status of setting the option is unknown.
- UNSPECIFIED - Enum constant in enum org.apache.arrow.flight.sql.CancelResult
-
Deprecated.
- UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
Protobuf deserialization fallback value: The session close status is unknown or not recognized.
- UNSPECIFIED_VALUE - Static variable in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
Protobuf deserialization fallback value: The status is unknown or unrecognized.
- UNTYPED - Enum constant in enum org.apache.arrow.vector.complex.impl.PromotableWriter.State
- UNUSED - Static variable in class org.apache.arrow.flatbuf.Feature
-
Needed to make flatbuffers happy.
- updateCommandBuilder(FlightSql.CommandStatementIngest.Builder) - Method in class org.apache.arrow.flight.sql.FlightSqlClient.ExecuteIngestOptions
- URI_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.Location
- 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
- 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 - Class in org.apache.arrow.flatbuf
-
Unicode with UTF-8 encoding
- Utf8 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Utf8 - Static variable in class org.apache.arrow.flatbuf.Type
- 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
- 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 - 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 - Enum constant in enum org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeID
- Utf8View - Static variable in class org.apache.arrow.flatbuf.Type
- Utf8View() - Constructor for class org.apache.arrow.flatbuf.Utf8View
- Utf8View() - Constructor for class org.apache.arrow.vector.types.pojo.ArrowType.Utf8View
- Utf8View.Vector - Class in org.apache.arrow.flatbuf
V
- V1 - Enum constant in enum org.apache.arrow.vector.types.MetadataVersion
- V1 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
-
0.1.0 (October 2016).
- V2 - Enum constant in enum org.apache.arrow.vector.types.MetadataVersion
- V2 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
-
0.2.0 (February 2017).
- V3 - Enum constant in enum org.apache.arrow.vector.types.MetadataVersion
- V3 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
-
0.3.0 -> 0.7.1 (May - December 2017).
- V4 - Enum constant in enum org.apache.arrow.vector.types.MetadataVersion
- V4 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
-
>= 0.8.0 (December 2017).
- V5 - Enum constant in enum org.apache.arrow.vector.types.MetadataVersion
- V5 - Static variable in class org.apache.arrow.flatbuf.MetadataVersion
-
>= 1.0.0 (July 2020).
- validate() - Method in class org.apache.arrow.vector.complex.LargeListViewVector
-
Validating LargeListViewVector creation based on the specification guideline.
- validate() - Method in class org.apache.arrow.vector.complex.ListViewVector
-
Validating ListViewVector creation based on the specification guideline.
- validate() - Method in interface org.apache.arrow.vector.ValueVector
- 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(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.
- 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() - Method in interface org.apache.arrow.vector.ValueVector
- 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.
- 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.BaseVariableWidthViewVector
-
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
- validateScalars() - Method in class org.apache.arrow.vector.ViewVarCharVector
- 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
- VALIDITY - Enum constant in enum org.apache.arrow.vector.BufferLayout.BufferType
- validityAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.LargeListViewVector
- validityAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.ListVector
- validityAllocationSizeInBytes - Variable in class org.apache.arrow.vector.complex.ListViewVector
- 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.BaseVariableWidthViewVector
- validityBuffer - Variable in class org.apache.arrow.vector.complex.LargeListVector
- validityBuffer - Variable in class org.apache.arrow.vector.complex.LargeListViewVector
- validityBuffer - Variable in class org.apache.arrow.vector.complex.ListVector
- validityBuffer - Variable in class org.apache.arrow.vector.complex.ListViewVector
- validityBuffer - Variable in class org.apache.arrow.vector.complex.StructVector
- validityVector() - Static method in class org.apache.arrow.vector.BufferLayout
- value - Variable in class org.apache.arrow.flight.SetSessionOptionsResult.Error
- 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.Float2Holder
- 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.NullableFloat2Holder
- 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() - Method in class org.apache.arrow.flatbuf.KeyValue
- value() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- value() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- 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
- 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.BaseVariableWidthViewVector
- valueCount - Variable in class org.apache.arrow.vector.complex.BaseLargeRepeatedValueViewVector
- valueCount - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- valueCount - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- valueCount - Variable in class org.apache.arrow.vector.complex.LargeListVector
- valueCount - Variable in class org.apache.arrow.vector.complex.NonNullableStructVector
- valueCount - Variable in class org.apache.arrow.vector.complex.RunEndEncodedVector
- 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
- ValueIterableVector<T> - Interface in org.apache.arrow.vector
- valueOf(int) - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionCancelQueryResult.CancelResult
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndSavepointRequest.EndSavepoint
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.ActionEndTransactionRequest.EndTransaction
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
Deprecated.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.impl.Flight.CancelStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.impl.Flight.FlightDescriptor.DescriptorType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - 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(Descriptors.EnumValueDescriptor) - 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(Descriptors.EnumValueDescriptor) - 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(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Nullable
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.Searchable
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlInfo
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlNullOrdering
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlOuterJoinsSupportLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedCaseSensitivity
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedElementActions
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedGroupBy
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedPositionedCommands
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetConcurrency
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedResultSetType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedSubqueries
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransaction
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedTransactions
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportedUnions
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlSupportsConvert
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SqlTransactionIsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedAnsi92SqlGrammarLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.SupportedSqlGrammar
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.UpdateDeleteRules
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
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.CloseSessionResult.Status
-
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(String) - Static method in enum org.apache.arrow.flight.impl.Flight.CloseSessionResult.Status
-
Returns the enum constant of this type with the specified name.
- 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(String) - Static method in enum org.apache.arrow.flight.impl.Flight.SessionOptionValue.OptionValueCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.ErrorValue
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.arrow.flight.SetSessionOptionsResult.ErrorValue
-
Returns the enum constant of this type with the specified name.
- 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(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(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(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
Returns the enum constant of this type with the specified name.
- 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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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.complex.impl.PromotableWriter.State
-
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.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.CloseSessionResult.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.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.CloseSessionResult.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.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.impl.Flight.SessionOptionValue.OptionValueCase
-
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.SetSessionOptionsResult.ErrorValue
-
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.SetSessionOptionsResult.ErrorValue
-
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.CommandStatementIngest.TableDefinitionOptions.TableExistsOption
-
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.CommandStatementIngest.TableDefinitionOptions.TableNotExistOption
-
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.complex.impl.PromotableWriter.State
-
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
- VALUES_FIELD_NUMBER - Static variable in class org.apache.arrow.flight.impl.Flight.SessionOptionValue.StringListValue
- 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.
- valuesVector - Variable in class org.apache.arrow.vector.complex.RunEndEncodedVector
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- varBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- varBinary(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- varBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- varBinary(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- VARBINARY - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- varChar() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- varChar() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- varChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- varChar(String) - 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(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- varChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- 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
- VARCHAR - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- 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
- VariableWidthFieldVector - Interface in org.apache.arrow.vector
-
A base interface for common functionalities in variable width vectors.
- 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.
- VARIADIC_DATA_BUFFERS - Enum constant in enum org.apache.arrow.vector.BufferLayout.BufferType
- 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.avro.consumers.BaseAvroConsumer
- 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.vector.complex.BaseLargeRepeatedValueViewVector
- vector - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueVector
- vector - Variable in class org.apache.arrow.vector.complex.BaseRepeatedValueViewVector
- vector - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- vector - Variable in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- vector - Variable in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- vector - Variable in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- vector - Variable in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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
- 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
- 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(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(FieldVector) - Constructor for class org.apache.arrow.vector.VectorSchemaRoot
-
Constructs a new instance containing the children of parent but not the parent itself.
- 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
VectorSchemaRoot
s with the same schema. - VectorSchemaRootAppender() - Constructor for class org.apache.arrow.vector.util.VectorSchemaRootAppender
- 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 aArrowRecordBatch
. - 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 theValueVector
. - VectorWithOrdinal(ValueVector, int) - Constructor for class org.apache.arrow.vector.complex.VectorWithOrdinal
- vendorName() - Method in class org.apache.arrow.vector.extension.OpaqueType
- 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
- viewBuffer - Variable in class org.apache.arrow.vector.BaseVariableWidthViewVector
- VIEWS - Enum constant in enum org.apache.arrow.vector.BufferLayout.BufferType
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- viewVarBinary() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- viewVarBinary() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- viewVarBinary(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- viewVarBinary(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- VIEWVARBINARY - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- ViewVarBinaryHolder - Class in org.apache.arrow.vector.holders
-
Source code generated using FreeMarker template ValueHolders.java
- ViewVarBinaryHolder() - Constructor for class org.apache.arrow.vector.holders.ViewVarBinaryHolder
- ViewVarBinaryHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
- ViewVarBinaryHolderReaderImpl(ViewVarBinaryHolder) - Constructor for class org.apache.arrow.vector.complex.impl.ViewVarBinaryHolderReaderImpl
- ViewVarBinaryReader - Interface in org.apache.arrow.vector.complex.reader
-
Source code generated using FreeMarker template ComplexReaders.java
- ViewVarBinaryReaderImpl - Class in org.apache.arrow.vector.complex.impl
-
Source code generated using FreeMarker template ComplexReaders.java
- ViewVarBinaryReaderImpl(ViewVarBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.ViewVarBinaryReaderImpl
- ViewVarBinaryVector - Class in org.apache.arrow.vector
-
ViewVarBinaryVector implements a variable width view vector of binary values which could be NULL.
- ViewVarBinaryVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.ViewVarBinaryVector
-
Instantiate a ViewVarBinaryVector.
- ViewVarBinaryVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.ViewVarBinaryVector
-
Instantiate a ViewVarBinaryVector.
- ViewVarBinaryVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.ViewVarBinaryVector
-
Instantiate a ViewVarBinaryVector.
- ViewVarBinaryWriter - Interface in org.apache.arrow.vector.complex.writer
- ViewVarBinaryWriterImpl - Class in org.apache.arrow.vector.complex.impl
- ViewVarBinaryWriterImpl(ViewVarBinaryVector) - Constructor for class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionMapWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- viewVarChar() - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- viewVarChar() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.ListWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.NullableStructWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.SingleStructWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- viewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- viewVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter.StructWriter
- VIEWVARCHAR - Enum constant in enum org.apache.arrow.vector.types.Types.MinorType
- ViewVarCharHolder - Class in org.apache.arrow.vector.holders
-
Source code generated using FreeMarker template ValueHolders.java
- ViewVarCharHolder() - Constructor for class org.apache.arrow.vector.holders.ViewVarCharHolder
- ViewVarCharHolderReaderImpl - Class in org.apache.arrow.vector.complex.impl
- ViewVarCharHolderReaderImpl(ViewVarCharHolder) - Constructor for class org.apache.arrow.vector.complex.impl.ViewVarCharHolderReaderImpl
- ViewVarCharReader - Interface in org.apache.arrow.vector.complex.reader
-
Source code generated using FreeMarker template ComplexReaders.java
- ViewVarCharReaderImpl - Class in org.apache.arrow.vector.complex.impl
-
Source code generated using FreeMarker template ComplexReaders.java
- ViewVarCharReaderImpl(ViewVarCharVector) - Constructor for class org.apache.arrow.vector.complex.impl.ViewVarCharReaderImpl
- ViewVarCharVector - Class in org.apache.arrow.vector
-
ViewVarCharVector implements a view of a variable width vector of VARCHAR values which could be NULL.
- ViewVarCharVector(String, BufferAllocator) - Constructor for class org.apache.arrow.vector.ViewVarCharVector
-
Instantiate a ViewVarCharVector.
- ViewVarCharVector(String, FieldType, BufferAllocator) - Constructor for class org.apache.arrow.vector.ViewVarCharVector
-
Instantiate a ViewVarCharVector.
- ViewVarCharVector(Field, BufferAllocator) - Constructor for class org.apache.arrow.vector.ViewVarCharVector
-
Instantiate a ViewVarCharVector.
- ViewVarCharWriter - Interface in org.apache.arrow.vector.complex.writer
- ViewVarCharWriterImpl - Class in org.apache.arrow.vector.complex.impl
- ViewVarCharWriterImpl(ViewVarCharVector) - Constructor for class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- viewVector() - Static method in class org.apache.arrow.vector.BufferLayout
- 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(boolean) - Method in class org.apache.arrow.flight.NoOpSessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a boolean.
- visit(boolean) - Method in interface org.apache.arrow.flight.SessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a boolean.
- visit(double) - Method in class org.apache.arrow.flight.NoOpSessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a double.
- visit(double) - Method in interface org.apache.arrow.flight.SessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a double.
- visit(long) - Method in class org.apache.arrow.flight.NoOpSessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a long.
- visit(long) - Method in interface org.apache.arrow.flight.SessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a long.
- visit(String) - Method in class org.apache.arrow.flight.NoOpSessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a String.
- visit(String) - Method in interface org.apache.arrow.flight.SessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing a String.
- visit(String[]) - Method in class org.apache.arrow.flight.NoOpSessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing an array of String.
- visit(String[]) - Method in interface org.apache.arrow.flight.SessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing an array of String.
- visit(Void) - Method in class org.apache.arrow.flight.NoOpSessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing no value.
- visit(Void) - Method in interface org.apache.arrow.flight.SessionOptionValueVisitor
-
A callback to handle SessionOptionValue containing no value.
- visit(BaseFixedWidthVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(BaseFixedWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- 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(BaseLargeVariableWidthVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(BaseLargeVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(BaseLargeVariableWidthVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(BaseVariableWidthVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(BaseVariableWidthVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(BaseVariableWidthVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(BaseVariableWidthViewVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(BaseVariableWidthViewVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(BaseVariableWidthViewVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(BaseVariableWidthViewVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(BaseVariableWidthViewVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(BaseVariableWidthViewVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(BaseVariableWidthViewVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(BaseVariableWidthViewVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(DenseUnionVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(DenseUnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(DenseUnionVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(FixedSizeListVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(FixedSizeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(FixedSizeListVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(LargeListVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(LargeListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(LargeListVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(LargeListViewVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(LargeListViewVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(LargeListViewVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(ListVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(ListVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(ListVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(ListVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(ListVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(ListViewVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(ListViewVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(ListViewVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(NonNullableStructVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(NonNullableStructVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(NonNullableStructVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(RunEndEncodedVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(RunEndEncodedVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(RunEndEncodedVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(RunEndEncodedVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(RunEndEncodedVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(UnionVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(UnionVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(UnionVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(UnionVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(UnionVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(ExtensionTypeVector<?>, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(ExtensionTypeVector<?>, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(ExtensionTypeVector<?>, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- 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(NullVector, IN) - Method in interface org.apache.arrow.vector.compare.VectorVisitor
- visit(NullVector, Void) - Method in class org.apache.arrow.vector.compare.TypeEqualsVisitor
- visit(NullVector, Void) - Method in class org.apache.arrow.vector.util.VectorAppender
- visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorBufferVisitor
- visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorDataVisitor
- visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorTypeVisitor
- visit(NullVector, Void) - Method in class org.apache.arrow.vector.validate.ValidateVectorVisitor
- visit(NullVector, Range) - Method in class org.apache.arrow.vector.compare.RangeEqualsVisitor
- visit(ArrowType.Binary) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Binary) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Binary) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.BinaryView) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.BinaryView) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.BinaryView) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Bool) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Bool) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Bool) - 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.Date) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Date) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Date) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Decimal) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Decimal) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Decimal) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Duration) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Duration) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Duration) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.ExtensionType) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.FixedSizeBinary) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.FixedSizeBinary) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.FixedSizeBinary) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.FixedSizeList) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.FixedSizeList) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.FixedSizeList) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.FloatingPoint) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.FloatingPoint) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.FloatingPoint) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Int) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Int) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Int) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Interval) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Interval) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Interval) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.LargeBinary) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.LargeBinary) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.LargeBinary) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.LargeList) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.LargeList) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.LargeList) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.LargeListView) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.LargeListView) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.LargeListView) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.LargeUtf8) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.LargeUtf8) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.LargeUtf8) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.List) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.List) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.List) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.ListView) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.ListView) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.ListView) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.Map) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Map) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Map) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.Null) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Null) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Null) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.PrimitiveType) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.RunEndEncoded) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.RunEndEncoded) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.RunEndEncoded) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.Struct) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Struct) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Struct) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.Time) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Time) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Time) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Timestamp) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Timestamp) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Timestamp) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Union) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Union) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Union) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.PrimitiveTypeVisitor
- visit(ArrowType.Utf8) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Utf8) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Utf8) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
- visit(ArrowType.Utf8View) - Method in class org.apache.arrow.adapter.jdbc.binder.ColumnBinderArrowTypeVisitor
- visit(ArrowType.Utf8View) - Method in interface org.apache.arrow.vector.types.pojo.ArrowType.ArrowTypeVisitor
- visit(ArrowType.Utf8View) - Method in class org.apache.arrow.vector.types.pojo.ArrowType.ComplexTypeVisitor
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.
- 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.Float2Holder
- 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.NullableFloat2Holder
- 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.NullableViewVarBinaryHolder
- WIDTH - Static variable in class org.apache.arrow.vector.holders.NullableViewVarCharHolder
- 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
- WIDTH - Static variable in class org.apache.arrow.vector.holders.ViewVarBinaryHolder
- WIDTH - Static variable in class org.apache.arrow.vector.holders.ViewVarCharHolder
- withCause(Throwable) - Method in class org.apache.arrow.flight.CallStatus
-
Return a copy of this status with the given exception as the cause.
- withDescription(String) - Method in class org.apache.arrow.flight.CallStatus
-
Return a copy of this status with an error message.
- 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. - withFlightSqlServerBulkIngestion(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Set a value for bulk ingestion support.
- withFlightSqlServerBulkIngestionTransaction(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Set a value for transaction support for bulk ingestion.
- 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. - withMetadata(ErrorFlightMetadata) - Method in class org.apache.arrow.flight.CallStatus
-
Return a copy of this status with associated exception metadata.
- withSqlAllTablesAreSelectable(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Sets a value for
FlightSql.SqlInfo.SQL_ALL_TABLES_ARE_SELECTABLE
in the builder. - 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
-
Sets a value for
FlightSql.SqlInfo.SQL_CORRELATED_SUBQUERIES_SUPPORTED
in the builder. - withSqlDataDefinitionCausesTransactionCommit(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Sets a value for
FlightSql.SqlInfo.SQL_DATA_DEFINITION_CAUSES_TRANSACTION_COMMIT
in the builder. - withSqlDataDefinitionsInTransactionsIgnored(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Sets a value for
FlightSql.SqlInfo.SQL_DATA_DEFINITIONS_IN_TRANSACTIONS_IGNORED
in the builder. - 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
-
Sets a value for
FlightSql.SqlInfo.SQL_DEFAULT_TRANSACTION_ISOLATION
in the builder. - 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. - withSqlMaxColumnsInTable(long) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Sets a value for
FlightSql.SqlInfo.SQL_MAX_COLUMNS_IN_TABLE
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. - withSqlNullOrdering(FlightSql.SqlNullOrdering) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Sets a value for
FlightSql.SqlInfo.SQL_NULL_ORDERING
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
-
Sets a value for
FlightSql.SqlInfo.SQL_STORED_FUNCTIONS_USING_CALL_SYNTAX_SUPPORTED
in the builder. - 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
-
Sets a value for
FlightSql.SqlInfo.SQL_SUPPORTED_POSITIONED_COMMANDS
in the builder. - 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
-
Sets a value for
FlightSql.SqlInfo.SQL_SUPPORTED_TRANSACTIONS_ISOLATION_LEVELS
in the builder. - 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
-
Sets a value for
FlightSql.SqlInfo.SQL_SUPPORTS_DIFFERENT_TABLE_CORRELATION_NAMES
in the builder. - withSqlSupportsExpressionsInOrderBy(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Sets a value for
FlightSql.SqlInfo.SQL_SUPPORTS_EXPRESSIONS_IN_ORDER_BY
in the builder. - withSqlSupportsIntegrityEnhancementFacility(boolean) - Method in class org.apache.arrow.flight.sql.SqlInfoBuilder
-
Sets a value for
FlightSql.SqlInfo.SQL_SUPPORTS_INTEGRITY_ENHANCEMENT_FACILITY
in the builder. - 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
-
Sets a value for
FlightSql.SqlInfo.SQL_SUPPORTS_NON_NULLABLE_COLUMNS
in the builder. - 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
-
Sets a value for
FlightSql.SqlInfo.SQL_SUPPORTS_TABLE_CORRELATION_NAMES
in the builder. - 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. - wrapForeignAllocation(ForeignAllocation) - Method in class org.apache.arrow.memory.RootAllocator
- 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(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(ByteBuffer) - Method in class org.apache.arrow.vector.util.ByteArrayReadableSeekableByteChannel
- write(ArrowBuf) - Method in class org.apache.arrow.vector.ipc.WriteChannel
-
Writes the buffer to the underlying channel.
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(BigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(BigIntHolder) - Method in interface org.apache.arrow.vector.complex.writer.BigIntWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(BitHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(BitHolder) - Method in interface org.apache.arrow.vector.complex.writer.BitWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(DateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(DateDayHolder) - Method in interface org.apache.arrow.vector.complex.writer.DateDayWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(DateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(DateMilliHolder) - Method in interface org.apache.arrow.vector.complex.writer.DateMilliWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(Decimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(Decimal256Holder) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(DecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(DecimalHolder) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(DurationHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(DurationHolder) - Method in interface org.apache.arrow.vector.complex.writer.DurationWriter
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(FixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(FixedSizeBinaryHolder) - Method in interface org.apache.arrow.vector.complex.writer.FixedSizeBinaryWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.Float2WriterImpl
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(Float2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(Float2Holder) - Method in interface org.apache.arrow.vector.complex.writer.Float2Writer
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(Float4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(Float4Holder) - Method in interface org.apache.arrow.vector.complex.writer.Float4Writer
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(Float8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(Float8Holder) - Method in interface org.apache.arrow.vector.complex.writer.Float8Writer
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(IntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(IntervalDayHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntervalDayWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(IntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(IntervalMonthDayNanoHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntervalMonthDayNanoWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(IntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(IntervalYearHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntervalYearWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(IntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(IntHolder) - Method in interface org.apache.arrow.vector.complex.writer.IntWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(LargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(LargeVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(LargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(LargeVarCharHolder) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarCharWriter
- write(NullableBigIntHolder) - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
- write(NullableBitHolder) - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
- write(NullableDateDayHolder) - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
- write(NullableDateMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
- write(NullableDecimal256Holder) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
- write(NullableDecimalHolder) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
- write(NullableDurationHolder) - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
- write(NullableFixedSizeBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
- write(NullableFloat2Holder) - Method in class org.apache.arrow.vector.complex.impl.Float2WriterImpl
- write(NullableFloat4Holder) - Method in class org.apache.arrow.vector.complex.impl.Float4WriterImpl
- write(NullableFloat8Holder) - Method in class org.apache.arrow.vector.complex.impl.Float8WriterImpl
- write(NullableIntervalDayHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalDayWriterImpl
- write(NullableIntervalMonthDayNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalMonthDayNanoWriterImpl
- write(NullableIntervalYearHolder) - Method in class org.apache.arrow.vector.complex.impl.IntervalYearWriterImpl
- write(NullableIntHolder) - Method in class org.apache.arrow.vector.complex.impl.IntWriterImpl
- write(NullableLargeVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
- write(NullableLargeVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
- write(NullableSmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
- write(NullableTimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
- write(NullableTimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
- write(NullableTimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
- write(NullableTimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
- write(NullableTimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
- write(NullableTimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
- write(NullableTimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
- write(NullableTimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
- write(NullableTimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
- write(NullableTimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
- write(NullableTimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
- write(NullableTimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
- write(NullableTinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
- write(NullableUInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
- write(NullableUInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
- write(NullableUInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
- write(NullableUInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
- write(NullableVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
- write(NullableVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
- write(NullableViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- write(NullableViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.SmallIntWriterImpl
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(SmallIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(SmallIntHolder) - Method in interface org.apache.arrow.vector.complex.writer.SmallIntWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMicroWriterImpl
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeMicroHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeMicroWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeMilliWriterImpl
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeMilliHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeMilliWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeNanoWriterImpl
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeNanoHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeNanoWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeSecWriterImpl
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeSecHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeSecWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroWriterImpl
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampMicroHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampMicroHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMicroWriter
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampMicroTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampMicroTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMicroTZWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliWriterImpl
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampMilliHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampMilliHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMilliWriter
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampMilliTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampMilliTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMilliTZWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoWriterImpl
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampNanoHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampNanoHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampNanoWriter
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampNanoTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampNanoTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampNanoTZWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecWriterImpl
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampSecHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampSecHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampSecWriter
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TimeStampSecTZHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TimeStampSecTZHolder) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampSecTZWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.TinyIntWriterImpl
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(TinyIntHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(TinyIntHolder) - Method in interface org.apache.arrow.vector.complex.writer.TinyIntWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt1WriterImpl
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(UInt1Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(UInt1Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt1Writer
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt2WriterImpl
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(UInt2Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(UInt2Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt2Writer
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt4WriterImpl
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(UInt4Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(UInt4Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt4Writer
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UInt8WriterImpl
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(UInt8Holder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(UInt8Holder) - Method in interface org.apache.arrow.vector.complex.writer.UInt8Writer
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(VarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
- write(VarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(VarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
- write(VarCharHolder) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(ViewVarBinaryHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- write(ViewVarBinaryHolder) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarBinaryWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- write(ViewVarCharHolder) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- write(ViewVarCharHolder) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarCharWriter
- write(FBSerializable, boolean) - Method in class org.apache.arrow.vector.ipc.WriteChannel
-
Writes the serialized flatbuffer to the underlying channel.
- write(VectorSchemaRoot) - Method in class org.apache.arrow.vector.ipc.JsonFileWriter
-
Writes the record batch to the JSON file.
- 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[]) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeBigEndianBytesToDecimal(byte[]) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeBigEndianBytesToDecimal(byte[]) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
- 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.
- writeBigEndianBytesToDecimal(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeBigEndianBytesToDecimal(byte[], ArrowType) - 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.UnionLargeListViewWriter
- 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.UnionListViewWriter
- 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.UnionViewWriter
- 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
- writeBigEndianBytesToDecimal256(byte[]) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeBigEndianBytesToDecimal256(byte[]) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeBigEndianBytesToDecimal256(byte[]) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
- 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.
- writeBigEndianBytesToDecimal256(byte[], ArrowType) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeBigEndianBytesToDecimal256(byte[], ArrowType) - 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.UnionLargeListViewWriter
- 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.UnionListViewWriter
- 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.UnionViewWriter
- 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
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.BigIntWriterImpl
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeBigInt(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeBigInt(long) - Method in interface org.apache.arrow.vector.complex.writer.BigIntWriter
- writeBigInt(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.BitWriterImpl
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeBit(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeBit(int) - Method in interface org.apache.arrow.vector.complex.writer.BitWriter
- writeBit(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- 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
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.DateDayWriterImpl
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeDateDay(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeDateDay(int) - Method in interface org.apache.arrow.vector.complex.writer.DateDayWriter
- writeDateDay(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.DateMilliWriterImpl
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeDateMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeDateMilli(long) - Method in interface org.apache.arrow.vector.complex.writer.DateMilliWriter
- writeDateMilli(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeDecimal(int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeDecimal(int, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
- writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDecimal(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- 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, 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.ComplexWriterImpl
- writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
- writeDecimal(long, ArrowBuf, ArrowType) - 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(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeDecimal(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeDecimal(long, ArrowBuf, ArrowType) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.DecimalWriterImpl
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeDecimal(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeDecimal(BigDecimal) - Method in interface org.apache.arrow.vector.complex.writer.DecimalWriter
- writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
- writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDecimal256(long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- 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, 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.ComplexWriterImpl
- writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
- writeDecimal256(long, ArrowBuf, ArrowType) - 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(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeDecimal256(long, ArrowBuf, ArrowType) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeDecimal256(long, ArrowBuf, ArrowType) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.Decimal256WriterImpl
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeDecimal256(BigDecimal) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeDecimal256(BigDecimal) - Method in interface org.apache.arrow.vector.complex.writer.Decimal256Writer
- writeDictionaryBatch(Dictionary) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
- writeDictionaryBatch(ArrowDictionaryBatch) - Method in class org.apache.arrow.vector.ipc.ArrowFileWriter
- writeDictionaryBatch(ArrowDictionaryBatch) - Method in class org.apache.arrow.vector.ipc.ArrowWriter
- 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.ComplexWriterImpl
- writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
-
Deprecated.If you experience errors with using this version of the method, switch to the holder version. The errors occur when using an untyped or unioned PromotableWriter, because this version of the method does not have enough information to infer the ArrowType.
- writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.DurationWriterImpl
- writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeDuration(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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.ComplexWriterImpl
- writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
-
Deprecated.If you experience errors with using this version of the method, switch to the holder version. The errors occur when using an untyped or unioned PromotableWriter, because this version of the method does not have enough information to infer the ArrowType.
- writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.FixedSizeBinaryWriterImpl
- writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeFixedSizeBinary(ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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 org.apache.arrow.memory.ArrowBuf
-
Set the provided float value at the writerIndex.
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.Float2WriterImpl
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeFloat2(short) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeFloat2(short) - Method in interface org.apache.arrow.vector.complex.writer.Float2Writer
- writeFloat2(short, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeFloat4(float) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeFloat4(float) - Method in interface org.apache.arrow.vector.complex.writer.Float4Writer
- writeFloat4(float, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeFloat8(double) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeFloat8(double) - Method in interface org.apache.arrow.vector.complex.writer.Float8Writer
- writeFloat8(double, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeInt(int) - Method in class org.apache.arrow.memory.ArrowBuf
-
Set the provided int value at the writerIndex.
- writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeInt(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeInt(int) - Method in interface org.apache.arrow.vector.complex.writer.IntWriter
- writeInt(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeIntervalDay(int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeIntervalDay(int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- 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.UnionListViewWriter
- 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.UnionViewWriter
- 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
- writeIntervalDay(int, int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeIntervalMonthDayNano(int, int, long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeIntervalMonthDayNano(int, int, long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- 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.UnionListViewWriter
- 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.UnionViewWriter
- 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
- writeIntervalMonthDayNano(int, int, long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeIntervalYear(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeIntervalYear(int) - Method in interface org.apache.arrow.vector.complex.writer.IntervalYearWriter
- writeIntervalYear(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- 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(byte[]) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeLargeVarBinary(byte[]) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeLargeVarBinary(byte[], int, int) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
- writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
- 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.UnionLargeListViewWriter
- writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarBinary(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarBinary(long, long, ArrowBuf) - 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(long, long, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeLargeVarBinary(ByteBuffer) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.LargeVarBinaryWriterImpl
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeLargeVarBinary(ByteBuffer, int, int) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarBinaryWriter
- writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
- 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.UnionLargeListViewWriter
- writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarChar(long, long, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarChar(long, long, ArrowBuf) - 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(long, long, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeLargeVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarCharWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.LargeVarCharWriterImpl
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeLargeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeLargeVarChar(Text) - Method in interface org.apache.arrow.vector.complex.writer.LargeVarCharWriter
- 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.ComplexWriterImpl
- 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.Float2WriterImpl
- 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.UnionLargeListViewWriter
- writeNull() - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeNull() - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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 class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- writeNull() - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- writeNull() - Method in interface org.apache.arrow.vector.complex.writer.BaseWriter
- writer - Variable in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writer - Variable in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writer - Variable in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writer - Variable in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writer - Variable in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- 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() - 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.
- writers - Variable in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeShort(int) - Method in class org.apache.arrow.memory.ArrowBuf
-
Set the provided int value as short at the writerIndex.
- writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeSmallInt(short) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeSmallInt(short) - Method in interface org.apache.arrow.vector.complex.writer.SmallIntWriter
- writeSmallInt(short, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeMicro(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeMicroWriter
- writeTimeMicro(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeMilli(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeMilli(int) - Method in interface org.apache.arrow.vector.complex.writer.TimeMilliWriter
- writeTimeMilli(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeNano(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeNanoWriter
- writeTimeNano(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeSec(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeSec(int) - Method in interface org.apache.arrow.vector.complex.writer.TimeSecWriter
- writeTimeSec(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeStampMicro(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeStampMicro(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMicroWriter
- writeTimeStampMicro(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
-
Deprecated.The holder version should be used instead otherwise the timezone will default to UTC.
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMicroTZWriterImpl
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampMicroTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeStampMilli(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeStampMilli(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampMilliWriter
- writeTimeStampMilli(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
-
Deprecated.The holder version should be used instead otherwise the timezone will default to UTC.
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampMilliTZWriterImpl
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampMilliTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeStampNano(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeStampNano(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampNanoWriter
- writeTimeStampNano(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
-
Deprecated.The holder version should be used instead otherwise the timezone will default to UTC.
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampNanoTZWriterImpl
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampNanoTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTimeStampSec(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTimeStampSec(long) - Method in interface org.apache.arrow.vector.complex.writer.TimeStampSecWriter
- writeTimeStampSec(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
-
Deprecated.The holder version should be used instead otherwise the timezone will default to UTC.
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.TimeStampSecTZWriterImpl
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTimeStampSecTZ(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- 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) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeTinyInt(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeTinyInt(byte) - Method in interface org.apache.arrow.vector.complex.writer.TinyIntWriter
- writeTinyInt(byte, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- 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.
- 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.CloseSessionRequest
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.CloseSessionResult
- 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.GetSessionOptionsRequest
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.GetSessionOptionsResult
- 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.SessionOptionValue.StringListValue
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.SessionOptionValue
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsRequest
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult.Error
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.SetSessionOptionsResult
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.impl.Flight.Ticket
- 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.CommandStatementIngest.TableDefinitionOptions
- writeTo(CodedOutputStream) - Method in class org.apache.arrow.flight.sql.impl.FlightSql.CommandStatementIngest
- 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.DoPutPreparedStatementResult
- 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
- writeToBuilder(StringBuilder, int) - Method in class org.apache.arrow.memory.util.StackTrace
-
Write the stack trace to a StringBuilder.
- writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeUInt1(byte) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeUInt1(byte) - Method in interface org.apache.arrow.vector.complex.writer.UInt1Writer
- writeUInt1(byte, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeUInt2(char) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeUInt2(char) - Method in interface org.apache.arrow.vector.complex.writer.UInt2Writer
- writeUInt2(char, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeUInt4(int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeUInt4(int) - Method in interface org.apache.arrow.vector.complex.writer.UInt4Writer
- writeUInt4(int, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeUInt8(long) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeUInt8(long) - Method in interface org.apache.arrow.vector.complex.writer.UInt8Writer
- writeUInt8(long, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeUncompressedLength(ArrowBuf, long) - Method in class org.apache.arrow.vector.compression.AbstractCompressionCodec
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
- writeVarBinary(byte[]) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
- writeVarBinary(byte[], int, int) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
- writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarBinary(int, int, ArrowBuf) - 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(int, int, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
- writeVarBinary(int, int, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
- writeVarBinary(ByteBuffer) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.VarBinaryWriterImpl
- writeVarBinary(ByteBuffer, int, int) - Method in interface org.apache.arrow.vector.complex.writer.VarBinaryWriter
- writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- 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.UnionLargeListViewWriter
- writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarChar(int, int, ArrowBuf) - 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(int, int, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
- writeVarChar(int, int, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
- writeVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.PromotableWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.VarCharWriterImpl
- writeVarChar(Text) - Method in interface org.apache.arrow.vector.complex.writer.VarCharWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarBinary(byte[]) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- writeViewVarBinary(byte[]) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarBinaryWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarBinary(byte[], int, int) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- writeViewVarBinary(byte[], int, int) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarBinaryWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarBinary(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- writeViewVarBinary(int, int, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarBinaryWriter
- writeViewVarBinary(int, int, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarBinary(ByteBuffer) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- writeViewVarBinary(ByteBuffer) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarBinaryWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarBinary(ByteBuffer, int, int) - Method in class org.apache.arrow.vector.complex.impl.ViewVarBinaryWriterImpl
- writeViewVarBinary(ByteBuffer, int, int) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarBinaryWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarChar(int, int, ArrowBuf) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- writeViewVarChar(int, int, ArrowBuf) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarCharWriter
- writeViewVarChar(int, int, ArrowBuf, byte) - Method in class org.apache.arrow.vector.complex.impl.DenseUnionWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarChar(String) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- writeViewVarChar(String) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarCharWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.ComplexWriterImpl
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.PromotableViewWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionFixedSizeListWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListViewWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionLargeListWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListViewWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionListWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionViewWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.UnionWriter
- writeViewVarChar(Text) - Method in class org.apache.arrow.vector.complex.impl.ViewVarCharWriterImpl
- writeViewVarChar(Text) - Method in interface org.apache.arrow.vector.complex.writer.ViewVarCharWriter
- writeZeros(long) - Method in class org.apache.arrow.vector.ipc.WriteChannel
-
Writes
zeroCount zeros the underlying channel.
X
- XDBC_BIGINT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_BIGINT = -5;
- XDBC_BIGINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_BIGINT = -5;
- XDBC_BINARY - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_BINARY = -2;
- XDBC_BINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_BINARY = -2;
- XDBC_BIT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_BIT = -7;
- XDBC_BIT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_BIT = -7;
- XDBC_CHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_CHAR = 1;
- XDBC_CHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_CHAR = 1;
- XDBC_DATE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DATE = 91;
- XDBC_DATE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DATE = 91;
- XDBC_DATETIME - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DATETIME = 9;
- XDBC_DATETIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DATETIME = 9;
- XDBC_DECIMAL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DECIMAL = 3;
- XDBC_DECIMAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DECIMAL = 3;
- XDBC_DOUBLE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DOUBLE = 8;
- XDBC_DOUBLE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_DOUBLE = 8;
- XDBC_FLOAT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_FLOAT = 6;
- XDBC_FLOAT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_FLOAT = 6;
- XDBC_INTEGER - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_INTEGER = 4;
- XDBC_INTEGER_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_INTEGER = 4;
- XDBC_INTERVAL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_INTERVAL = 10;
- XDBC_INTERVAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_INTERVAL = 10;
- XDBC_LONGVARBINARY - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_LONGVARBINARY = -4;
- XDBC_LONGVARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_LONGVARBINARY = -4;
- XDBC_LONGVARCHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_LONGVARCHAR = -1;
- XDBC_LONGVARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_LONGVARCHAR = -1;
- XDBC_NUMERIC - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_NUMERIC = 2;
- XDBC_NUMERIC_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_NUMERIC = 2;
- XDBC_REAL - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_REAL = 7;
- XDBC_REAL_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_REAL = 7;
- XDBC_SMALLINT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_SMALLINT = 5;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_DAY_TO_HOUR = 8;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_DAY_TO_MINUTE = 9;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_DAY_TO_SECOND = 10;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_HOUR_TO_MINUTE = 11;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_HOUR_TO_SECOND = 12;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_DAY = 103;
- XDBC_SUBCODE_INTERVAL_DAY_TO_HOUR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_DAY_TO_HOUR = 108;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_DAY_TO_MINUTE = 109;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_DAY_TO_SECOND = 110;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_HOUR = 104;
- XDBC_SUBCODE_INTERVAL_HOUR_TO_MINUTE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_HOUR_TO_MINUTE = 111;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_HOUR_TO_SECOND = 112;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_MINUTE = 105;
- XDBC_SUBCODE_INTERVAL_MINUTE_TO_SECOND - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_MINUTE_TO_SECOND = 113;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_MONTH = 102;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_SECOND = 106;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_YEAR = 101;
- XDBC_SUBCODE_INTERVAL_YEAR_TO_MONTH - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_INTERVAL_YEAR_TO_MONTH = 107;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_MINUTE_TO_SECOND = 13;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_SECOND = 6;
- XDBC_SUBCODE_SECOND_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_SECOND = 6;
- XDBC_SUBCODE_TIME - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_TIME = 2;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_TIME_WITH_TIMEZONE = 4;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_TIMESTAMP = 3;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_TIMESTAMP_WITH_TIMEZONE = 5;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_UNKNOWN = 0;
- XDBC_SUBCODE_UNKNOWN_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_UNKNOWN = 0;
- XDBC_SUBCODE_YEAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_YEAR = 1;
- XDBC_SUBCODE_YEAR_TO_MONTH - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDatetimeSubcode
-
XDBC_SUBCODE_YEAR_TO_MONTH = 7;
- 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 - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_TIME = 92;
- XDBC_TIME_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_TIME = 92;
- XDBC_TIMESTAMP - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_TIMESTAMP = 93;
- XDBC_TIMESTAMP_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_TIMESTAMP = 93;
- XDBC_TINYINT - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_TINYINT = -6;
- XDBC_TINYINT_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_TINYINT = -6;
- XDBC_UNKNOWN_TYPE - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_UNKNOWN_TYPE = 0;
- XDBC_UNKNOWN_TYPE_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_UNKNOWN_TYPE = 0;
- XDBC_VARBINARY - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_VARBINARY = -3;
- XDBC_VARBINARY_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_VARBINARY = -3;
- XDBC_VARCHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_VARCHAR = 12;
- XDBC_VARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_VARCHAR = 12;
- XDBC_WCHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_WCHAR = -8;
- XDBC_WCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_WCHAR = -8;
- XDBC_WVARCHAR - Enum constant in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_WVARCHAR = -9;
- XDBC_WVARCHAR_VALUE - Static variable in enum org.apache.arrow.flight.sql.impl.FlightSql.XdbcDataType
-
XDBC_WVARCHAR = -9;
Y
- YEAR_MONTH - Enum constant in enum org.apache.arrow.vector.types.IntervalUnit
-
Values are stored as number of months (which can be converted into years and months via division).
- 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 class org.apache.arrow.vector.BaseVariableWidthViewVector
-
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() - Constructor for class org.apache.arrow.vector.ZeroVector
-
Deprecated.
- 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.
- ZSTD - Enum constant in enum org.apache.arrow.vector.compression.CompressionUtil.CodecType
- 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, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Binary.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BinaryView.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Block.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BodyCompression.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Bool.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Buffer.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Date.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Decimal.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryBatch.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Duration.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Field.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FieldNode.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeList.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FloatingPoint.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Footer.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Int.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Interval.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.KeyValue.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeBinary.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeList.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeListView.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeUtf8.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.List.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.ListView.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Map.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Message.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Null.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RecordBatch.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RunEndEncoded.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Schema.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensor.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Struct_.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Tensor.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.TensorDim.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Time.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Timestamp.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Union.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8.Vector
- __assign(int, int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8View.Vector
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Binary
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BinaryView
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Block
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.BodyCompression
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Bool
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Buffer
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Date
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Decimal
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryBatch
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.DictionaryEncoding
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Duration
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Field
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FieldNode
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeBinary
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FixedSizeList
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.FloatingPoint
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Footer
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Int
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Interval
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.KeyValue
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeBinary
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeList
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeListView
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.LargeUtf8
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.List
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.ListView
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Map
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Message
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Null
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RecordBatch
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.RunEndEncoded
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Schema
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseMatrixIndexCSX
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensor
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCOO
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.SparseTensorIndexCSF
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Struct_
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Tensor
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.TensorDim
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Time
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Timestamp
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Union
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8
- __assign(int, ByteBuffer) - Method in class org.apache.arrow.flatbuf.Utf8View
- __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
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
AllocationReservation.add(long)
instead