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.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.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.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.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.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 - 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.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.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.
- 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.UnionFixedSizeListReader
- 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.
AllocationReservation.add(long)
instead