Skip to main content
Ctrl+K
Apache Arrow v22.0.0 - Home Apache Arrow v22.0.0 - Home
  • Specifications
  • Development
  • Implementations
  • GitHub
  • LinkedIn
  • BlueSky
  • Specifications
  • Development
  • Implementations
  • GitHub
  • LinkedIn
  • BlueSky

Section Navigation

  • .NET
  • C++
    • Getting Started
      • Using Arrow C++ in your own project
      • Conventions
      • Basic Arrow Data Structures
      • Arrow File I/O
      • Arrow Compute
      • Arrow Datasets
    • User Guide
      • High-Level Overview
      • Memory Management
      • Arrays
      • Data Types
      • Tabular Data
      • Compute Functions
      • The Gandiva Expression Compiler
        • Gandiva Expression, Projector, and Filter
        • Gandiva External Functions Development Guide
      • Acero: A C++ streaming execution engine
        • Acero Overview
        • Acero User’s Guide
        • Using Acero with Substrait
      • Input / output and filesystems
      • Reading and writing the Arrow IPC format
      • Reading and Writing ORC files
      • Reading and writing Parquet files
      • Reading and Writing CSV files
      • Reading JSON files
      • Tabular Datasets
      • Arrow Flight RPC
      • Debugging code using Arrow
      • Thread Management
      • OpenTelemetry
      • Environment Variables
    • Examples
      • Minimal build using CMake
      • Compute and Write CSV Example
      • Arrow Datasets example
      • Parquet column encryption
      • Row to columnar conversion
      • std::tuple-like ranges to Arrow
      • Converting RecordBatch to Tensor
    • API Reference
      • Programming Support
      • Memory (management)
      • Thread (management)
      • Data Types
      • Arrays
      • Extension
      • Scalars
      • Array Builders
      • Two-dimensional Datasets
      • C Interfaces
      • Compute Functions
      • Streaming Execution (Acero)
      • Gandiva Expression Compiler
      • Tensors
      • Utilities
      • Asynchronous programming
      • Input / output
      • Arrow IPC
      • File Formats
      • CUDA support
      • Arrow Flight RPC
      • Arrow Flight SQL
      • Filesystems
      • Dataset
    • C++ Development
      • Building Arrow C++
      • Development Guidelines
      • Developing on Windows
      • Cross compiling for WebAssembly with Emscripten
      • Conventions
      • Fuzzing Arrow C++
      • Developing Arrow C++ Compute
      • Developing Acero
        • Swiss Table
    • C++ Cookbook
  • C GLib
    • Apache Arrow GLib
    • Apache Arrow CUDA GLib
    • Apache Arrow Dataset
    • Apache Arrow Flight GLib
    • Apache Arrow Flight SQL GLib
    • Apache Parquet GLib
    • Gandiva GLib
  • Go
  • Java
    • Quick Start Guide
    • High-Level Overview
    • Installing Java Modules
    • Memory Management
    • ValueVector
    • Tabular Data
    • Table
    • Reading/Writing IPC formats
    • Java Algorithms
    • Arrow Flight RPC
    • Arrow Flight SQL
    • Arrow Flight SQL JDBC Driver
    • Dataset
    • Substrait
    • C Data Interface
    • Arrow JDBC Adapter
    • Reference (javadoc)
    • Java cookbook
  • JavaScript
  • Julia
  • MATLAB
  • Python
    • Installing PyArrow
    • Getting Started
    • Data Types and In-Memory Data Model
    • Compute Functions
    • Memory and IO Interfaces
    • Streaming, Serialization, and IPC
    • Filesystem Interface
    • NumPy Integration
    • Pandas Integration
    • Dataframe Interchange Protocol
    • The DLPack Protocol
    • Timestamps
    • Reading and Writing the Apache ORC Format
    • Reading and Writing CSV files
    • Feather File Format
    • Reading JSON files
    • Reading and Writing the Apache Parquet Format
    • Tabular Datasets
    • Arrow Flight RPC
    • Extending PyArrow
    • PyArrow Integrations
      • Substrait
      • Integrating PyArrow with R
      • Integrating PyArrow with Java
      • Using pyarrow from C++ and Cython Code
      • CUDA Integration
    • Environment Variables
    • API Reference
      • Data Types and Schemas
        • pyarrow.null
        • pyarrow.bool_
        • pyarrow.int8
        • pyarrow.int16
        • pyarrow.int32
        • pyarrow.int64
        • pyarrow.uint8
        • pyarrow.uint16
        • pyarrow.uint32
        • pyarrow.uint64
        • pyarrow.float16
        • pyarrow.float32
        • pyarrow.float64
        • pyarrow.time32
        • pyarrow.time64
        • pyarrow.timestamp
        • pyarrow.date32
        • pyarrow.date64
        • pyarrow.duration
        • pyarrow.month_day_nano_interval
        • pyarrow.binary
        • pyarrow.string
        • pyarrow.utf8
        • pyarrow.large_binary
        • pyarrow.large_string
        • pyarrow.large_utf8
        • pyarrow.binary_view
        • pyarrow.string_view
        • pyarrow.decimal128
        • pyarrow.decimal256
        • pyarrow.list_
        • pyarrow.large_list
        • pyarrow.list_view
        • pyarrow.large_list_view
        • pyarrow.map_
        • pyarrow.struct
        • pyarrow.dictionary
        • pyarrow.run_end_encoded
        • pyarrow.fixed_shape_tensor
        • pyarrow.union
        • pyarrow.dense_union
        • pyarrow.sparse_union
        • pyarrow.opaque
        • pyarrow.bool8
        • pyarrow.uuid
        • pyarrow.json_
        • pyarrow.field
        • pyarrow.schema
        • pyarrow.from_numpy_dtype
        • pyarrow.unify_schemas
        • pyarrow.DataType
        • pyarrow.DictionaryType
        • pyarrow.ListType
        • pyarrow.ListViewType
        • pyarrow.FixedSizeListType
        • pyarrow.LargeListType
        • pyarrow.LargeListViewType
        • pyarrow.MapType
        • pyarrow.StructType
        • pyarrow.UnionType
        • pyarrow.DenseUnionType
        • pyarrow.SparseUnionType
        • pyarrow.TimestampType
        • pyarrow.Time32Type
        • pyarrow.Time64Type
        • pyarrow.DurationType
        • pyarrow.FixedSizeBinaryType
        • pyarrow.Decimal32Type
        • pyarrow.Decimal64Type
        • pyarrow.Decimal128Type
        • pyarrow.Decimal256Type
        • pyarrow.Field
        • pyarrow.Schema
        • pyarrow.RunEndEncodedType
        • pyarrow.BaseExtensionType
        • pyarrow.ExtensionType
        • pyarrow.UnknownExtensionType
        • pyarrow.register_extension_type
        • pyarrow.unregister_extension_type
        • pyarrow.FixedShapeTensorType
        • pyarrow.OpaqueType
        • pyarrow.JsonType
        • pyarrow.UuidType
        • pyarrow.Bool8Type
        • pyarrow.types.is_boolean
        • pyarrow.types.is_integer
        • pyarrow.types.is_signed_integer
        • pyarrow.types.is_unsigned_integer
        • pyarrow.types.is_int8
        • pyarrow.types.is_int16
        • pyarrow.types.is_int32
        • pyarrow.types.is_int64
        • pyarrow.types.is_uint8
        • pyarrow.types.is_uint16
        • pyarrow.types.is_uint32
        • pyarrow.types.is_uint64
        • pyarrow.types.is_floating
        • pyarrow.types.is_float16
        • pyarrow.types.is_float32
        • pyarrow.types.is_float64
        • pyarrow.types.is_decimal
        • pyarrow.types.is_decimal128
        • pyarrow.types.is_decimal256
        • pyarrow.types.is_list
        • pyarrow.types.is_large_list
        • pyarrow.types.is_fixed_size_list
        • pyarrow.types.is_list_view
        • pyarrow.types.is_large_list_view
        • pyarrow.types.is_struct
        • pyarrow.types.is_union
        • pyarrow.types.is_nested
        • pyarrow.types.is_run_end_encoded
        • pyarrow.types.is_temporal
        • pyarrow.types.is_timestamp
        • pyarrow.types.is_date
        • pyarrow.types.is_date32
        • pyarrow.types.is_date64
        • pyarrow.types.is_time
        • pyarrow.types.is_time32
        • pyarrow.types.is_time64
        • pyarrow.types.is_duration
        • pyarrow.types.is_interval
        • pyarrow.types.is_null
        • pyarrow.types.is_binary
        • pyarrow.types.is_unicode
        • pyarrow.types.is_string
        • pyarrow.types.is_large_binary
        • pyarrow.types.is_large_unicode
        • pyarrow.types.is_large_string
        • pyarrow.types.is_binary_view
        • pyarrow.types.is_string_view
        • pyarrow.types.is_fixed_size_binary
        • pyarrow.types.is_map
        • pyarrow.types.is_dictionary
        • pyarrow.types.is_primitive
        • pyarrow.types.TypesEnum
      • Arrays and Scalars
        • pyarrow.array
        • pyarrow.nulls
        • pyarrow.Array
        • pyarrow.BooleanArray
        • pyarrow.FloatingPointArray
        • pyarrow.IntegerArray
        • pyarrow.Int8Array
        • pyarrow.Int16Array
        • pyarrow.Int32Array
        • pyarrow.Int64Array
        • pyarrow.NullArray
        • pyarrow.NumericArray
        • pyarrow.UInt8Array
        • pyarrow.UInt16Array
        • pyarrow.UInt32Array
        • pyarrow.UInt64Array
        • pyarrow.HalfFloatArray
        • pyarrow.FloatArray
        • pyarrow.DoubleArray
        • pyarrow.BinaryArray
        • pyarrow.StringArray
        • pyarrow.FixedSizeBinaryArray
        • pyarrow.LargeBinaryArray
        • pyarrow.LargeStringArray
        • pyarrow.BinaryViewArray
        • pyarrow.StringViewArray
        • pyarrow.Time32Array
        • pyarrow.Time64Array
        • pyarrow.Date32Array
        • pyarrow.Date64Array
        • pyarrow.TimestampArray
        • pyarrow.DurationArray
        • pyarrow.MonthDayNanoIntervalArray
        • pyarrow.Decimal32Array
        • pyarrow.Decimal64Array
        • pyarrow.Decimal128Array
        • pyarrow.Decimal256Array
        • pyarrow.DictionaryArray
        • pyarrow.ListArray
        • pyarrow.FixedSizeListArray
        • pyarrow.LargeListArray
        • pyarrow.ListViewArray
        • pyarrow.LargeListViewArray
        • pyarrow.MapArray
        • pyarrow.RunEndEncodedArray
        • pyarrow.StructArray
        • pyarrow.UnionArray
        • pyarrow.ExtensionArray
        • pyarrow.FixedShapeTensorArray
        • pyarrow.OpaqueArray
        • pyarrow.JsonArray
        • pyarrow.UuidArray
        • pyarrow.Bool8Array
        • pyarrow.scalar
        • pyarrow.NA
        • pyarrow.Scalar
        • pyarrow.BooleanScalar
        • pyarrow.Int8Scalar
        • pyarrow.Int16Scalar
        • pyarrow.Int32Scalar
        • pyarrow.Int64Scalar
        • pyarrow.NullScalar
        • pyarrow.UInt8Scalar
        • pyarrow.UInt16Scalar
        • pyarrow.UInt32Scalar
        • pyarrow.UInt64Scalar
        • pyarrow.HalfFloatScalar
        • pyarrow.FloatScalar
        • pyarrow.DoubleScalar
        • pyarrow.BinaryScalar
        • pyarrow.StringScalar
        • pyarrow.FixedSizeBinaryScalar
        • pyarrow.LargeBinaryScalar
        • pyarrow.LargeStringScalar
        • pyarrow.BinaryViewScalar
        • pyarrow.StringViewScalar
        • pyarrow.Time32Scalar
        • pyarrow.Time64Scalar
        • pyarrow.Date32Scalar
        • pyarrow.Date64Scalar
        • pyarrow.TimestampScalar
        • pyarrow.DurationScalar
        • pyarrow.MonthDayNanoIntervalScalar
        • pyarrow.Decimal128Scalar
        • pyarrow.Decimal256Scalar
        • pyarrow.DictionaryScalar
        • pyarrow.RunEndEncodedScalar
        • pyarrow.ListScalar
        • pyarrow.FixedSizeListScalar
        • pyarrow.LargeListScalar
        • pyarrow.ListViewScalar
        • pyarrow.LargeListViewScalar
        • pyarrow.MapScalar
        • pyarrow.StructScalar
        • pyarrow.UnionScalar
        • pyarrow.ExtensionScalar
        • pyarrow.FixedShapeTensorScalar
        • pyarrow.OpaqueScalar
        • pyarrow.JsonScalar
        • pyarrow.UuidScalar
        • pyarrow.Bool8Scalar
      • Buffers and Memory
        • pyarrow.allocate_buffer
        • pyarrow.py_buffer
        • pyarrow.foreign_buffer
        • pyarrow.Buffer
        • pyarrow.ResizableBuffer
        • pyarrow.Codec
        • pyarrow.compress
        • pyarrow.decompress
        • pyarrow.MemoryPool
        • pyarrow.default_memory_pool
        • pyarrow.jemalloc_memory_pool
        • pyarrow.mimalloc_memory_pool
        • pyarrow.system_memory_pool
        • pyarrow.jemalloc_set_decay_ms
        • pyarrow.set_memory_pool
        • pyarrow.log_memory_allocations
        • pyarrow.total_allocated_bytes
      • Tables and Tensors
        • pyarrow.chunked_array
        • pyarrow.concat_arrays
        • pyarrow.concat_tables
        • pyarrow.record_batch
        • pyarrow.concat_batches
        • pyarrow.table
        • pyarrow.ChunkedArray
        • pyarrow.RecordBatch
        • pyarrow.Table
        • pyarrow.TableGroupBy
        • pyarrow.RecordBatchReader
        • pyarrow.interchange.from_dataframe
        • pyarrow.Tensor
      • Compute Functions
        • pyarrow.compute.all
        • pyarrow.compute.any
        • pyarrow.compute.approximate_median
        • pyarrow.compute.count
        • pyarrow.compute.count_distinct
        • pyarrow.compute.index
        • pyarrow.compute.max
        • pyarrow.compute.mean
        • pyarrow.compute.min
        • pyarrow.compute.min_max
        • pyarrow.compute.mode
        • pyarrow.compute.pivot_wider
        • pyarrow.compute.product
        • pyarrow.compute.quantile
        • pyarrow.compute.stddev
        • pyarrow.compute.sum
        • pyarrow.compute.tdigest
        • pyarrow.compute.variance
        • pyarrow.compute.cumulative_sum
        • pyarrow.compute.cumulative_sum_checked
        • pyarrow.compute.cumulative_prod
        • pyarrow.compute.cumulative_prod_checked
        • pyarrow.compute.cumulative_max
        • pyarrow.compute.cumulative_min
        • pyarrow.compute.abs
        • pyarrow.compute.abs_checked
        • pyarrow.compute.add
        • pyarrow.compute.add_checked
        • pyarrow.compute.divide
        • pyarrow.compute.divide_checked
        • pyarrow.compute.multiply
        • pyarrow.compute.multiply_checked
        • pyarrow.compute.negate
        • pyarrow.compute.negate_checked
        • pyarrow.compute.power
        • pyarrow.compute.power_checked
        • pyarrow.compute.sign
        • pyarrow.compute.sqrt
        • pyarrow.compute.sqrt_checked
        • pyarrow.compute.subtract
        • pyarrow.compute.subtract_checked
        • pyarrow.compute.bit_wise_and
        • pyarrow.compute.bit_wise_not
        • pyarrow.compute.bit_wise_or
        • pyarrow.compute.bit_wise_xor
        • pyarrow.compute.shift_left
        • pyarrow.compute.shift_left_checked
        • pyarrow.compute.shift_right
        • pyarrow.compute.shift_right_checked
        • pyarrow.compute.ceil
        • pyarrow.compute.floor
        • pyarrow.compute.round
        • pyarrow.compute.round_to_multiple
        • pyarrow.compute.trunc
        • pyarrow.compute.ln
        • pyarrow.compute.ln_checked
        • pyarrow.compute.log10
        • pyarrow.compute.log10_checked
        • pyarrow.compute.log1p
        • pyarrow.compute.log1p_checked
        • pyarrow.compute.log2
        • pyarrow.compute.log2_checked
        • pyarrow.compute.logb
        • pyarrow.compute.logb_checked
        • pyarrow.compute.acos
        • pyarrow.compute.acos_checked
        • pyarrow.compute.asin
        • pyarrow.compute.asin_checked
        • pyarrow.compute.atan
        • pyarrow.compute.atan2
        • pyarrow.compute.cos
        • pyarrow.compute.cos_checked
        • pyarrow.compute.sin
        • pyarrow.compute.sin_checked
        • pyarrow.compute.tan
        • pyarrow.compute.tan_checked
        • pyarrow.compute.equal
        • pyarrow.compute.greater
        • pyarrow.compute.greater_equal
        • pyarrow.compute.less
        • pyarrow.compute.less_equal
        • pyarrow.compute.not_equal
        • pyarrow.compute.max_element_wise
        • pyarrow.compute.min_element_wise
        • pyarrow.compute.and_
        • pyarrow.compute.and_kleene
        • pyarrow.compute.and_not
        • pyarrow.compute.and_not_kleene
        • pyarrow.compute.invert
        • pyarrow.compute.or_
        • pyarrow.compute.or_kleene
        • pyarrow.compute.xor
        • pyarrow.compute.ascii_is_alnum
        • pyarrow.compute.ascii_is_alpha
        • pyarrow.compute.ascii_is_decimal
        • pyarrow.compute.ascii_is_lower
        • pyarrow.compute.ascii_is_printable
        • pyarrow.compute.ascii_is_space
        • pyarrow.compute.ascii_is_upper
        • pyarrow.compute.utf8_is_alnum
        • pyarrow.compute.utf8_is_alpha
        • pyarrow.compute.utf8_is_decimal
        • pyarrow.compute.utf8_is_digit
        • pyarrow.compute.utf8_is_lower
        • pyarrow.compute.utf8_is_numeric
        • pyarrow.compute.utf8_is_printable
        • pyarrow.compute.utf8_is_space
        • pyarrow.compute.utf8_is_upper
        • pyarrow.compute.ascii_is_title
        • pyarrow.compute.utf8_is_title
        • pyarrow.compute.string_is_ascii
        • pyarrow.compute.ascii_capitalize
        • pyarrow.compute.ascii_lower
        • pyarrow.compute.ascii_reverse
        • pyarrow.compute.ascii_swapcase
        • pyarrow.compute.ascii_title
        • pyarrow.compute.ascii_upper
        • pyarrow.compute.binary_length
        • pyarrow.compute.binary_repeat
        • pyarrow.compute.binary_replace_slice
        • pyarrow.compute.binary_reverse
        • pyarrow.compute.replace_substring
        • pyarrow.compute.replace_substring_regex
        • pyarrow.compute.utf8_capitalize
        • pyarrow.compute.utf8_length
        • pyarrow.compute.utf8_lower
        • pyarrow.compute.utf8_replace_slice
        • pyarrow.compute.utf8_reverse
        • pyarrow.compute.utf8_swapcase
        • pyarrow.compute.utf8_title
        • pyarrow.compute.utf8_upper
        • pyarrow.compute.ascii_center
        • pyarrow.compute.ascii_lpad
        • pyarrow.compute.ascii_rpad
        • pyarrow.compute.utf8_center
        • pyarrow.compute.utf8_lpad
        • pyarrow.compute.utf8_rpad
        • pyarrow.compute.utf8_zero_fill
        • pyarrow.compute.ascii_ltrim
        • pyarrow.compute.ascii_ltrim_whitespace
        • pyarrow.compute.ascii_rtrim
        • pyarrow.compute.ascii_rtrim_whitespace
        • pyarrow.compute.ascii_trim
        • pyarrow.compute.ascii_trim_whitespace
        • pyarrow.compute.utf8_ltrim
        • pyarrow.compute.utf8_ltrim_whitespace
        • pyarrow.compute.utf8_rtrim
        • pyarrow.compute.utf8_rtrim_whitespace
        • pyarrow.compute.utf8_trim
        • pyarrow.compute.utf8_trim_whitespace
        • pyarrow.compute.ascii_split_whitespace
        • pyarrow.compute.split_pattern
        • pyarrow.compute.split_pattern_regex
        • pyarrow.compute.utf8_split_whitespace
        • pyarrow.compute.extract_regex
        • pyarrow.compute.binary_join
        • pyarrow.compute.binary_join_element_wise
        • pyarrow.compute.binary_slice
        • pyarrow.compute.utf8_slice_codeunits
        • pyarrow.compute.count_substring
        • pyarrow.compute.count_substring_regex
        • pyarrow.compute.ends_with
        • pyarrow.compute.find_substring
        • pyarrow.compute.find_substring_regex
        • pyarrow.compute.index_in
        • pyarrow.compute.is_in
        • pyarrow.compute.match_like
        • pyarrow.compute.match_substring
        • pyarrow.compute.match_substring_regex
        • pyarrow.compute.starts_with
        • pyarrow.compute.indices_nonzero
        • pyarrow.compute.is_finite
        • pyarrow.compute.is_inf
        • pyarrow.compute.is_nan
        • pyarrow.compute.is_null
        • pyarrow.compute.is_valid
        • pyarrow.compute.true_unless_null
        • pyarrow.compute.case_when
        • pyarrow.compute.choose
        • pyarrow.compute.coalesce
        • pyarrow.compute.if_else
        • pyarrow.compute.cast
        • pyarrow.compute.ceil_temporal
        • pyarrow.compute.floor_temporal
        • pyarrow.compute.round_temporal
        • pyarrow.compute.run_end_decode
        • pyarrow.compute.run_end_encode
        • pyarrow.compute.strftime
        • pyarrow.compute.strptime
        • pyarrow.compute.day
        • pyarrow.compute.day_of_week
        • pyarrow.compute.day_of_year
        • pyarrow.compute.hour
        • pyarrow.compute.iso_week
        • pyarrow.compute.iso_year
        • pyarrow.compute.iso_calendar
        • pyarrow.compute.is_leap_year
        • pyarrow.compute.microsecond
        • pyarrow.compute.millisecond
        • pyarrow.compute.minute
        • pyarrow.compute.month
        • pyarrow.compute.nanosecond
        • pyarrow.compute.quarter
        • pyarrow.compute.second
        • pyarrow.compute.subsecond
        • pyarrow.compute.us_week
        • pyarrow.compute.us_year
        • pyarrow.compute.week
        • pyarrow.compute.year
        • pyarrow.compute.year_month_day
        • pyarrow.compute.day_time_interval_between
        • pyarrow.compute.days_between
        • pyarrow.compute.hours_between
        • pyarrow.compute.microseconds_between
        • pyarrow.compute.milliseconds_between
        • pyarrow.compute.minutes_between
        • pyarrow.compute.month_day_nano_interval_between
        • pyarrow.compute.month_interval_between
        • pyarrow.compute.nanoseconds_between
        • pyarrow.compute.quarters_between
        • pyarrow.compute.seconds_between
        • pyarrow.compute.weeks_between
        • pyarrow.compute.years_between
        • pyarrow.compute.assume_timezone
        • pyarrow.compute.local_timestamp
        • pyarrow.compute.dictionary_encode
        • pyarrow.compute.unique
        • pyarrow.compute.value_counts
        • pyarrow.compute.array_filter
        • pyarrow.compute.array_take
        • pyarrow.compute.drop_null
        • pyarrow.compute.filter
        • pyarrow.compute.take
        • pyarrow.compute.array_sort_indices
        • pyarrow.compute.partition_nth_indices
        • pyarrow.compute.select_k_unstable
        • pyarrow.compute.sort_indices
        • pyarrow.compute.fill_null
        • pyarrow.compute.fill_null_backward
        • pyarrow.compute.fill_null_forward
        • pyarrow.compute.list_element
        • pyarrow.compute.list_flatten
        • pyarrow.compute.list_parent_indices
        • pyarrow.compute.list_slice
        • pyarrow.compute.list_value_length
        • pyarrow.compute.make_struct
        • pyarrow.compute.map_lookup
        • pyarrow.compute.replace_with_mask
        • pyarrow.compute.struct_field
        • pyarrow.compute.pairwise_diff
        • pyarrow.compute.ArraySortOptions
        • pyarrow.compute.AssumeTimezoneOptions
        • pyarrow.compute.CastOptions
        • pyarrow.compute.CountOptions
        • pyarrow.compute.CumulativeSumOptions
        • pyarrow.compute.DayOfWeekOptions
        • pyarrow.compute.DictionaryEncodeOptions
        • pyarrow.compute.ElementWiseAggregateOptions
        • pyarrow.compute.ExtractRegexOptions
        • pyarrow.compute.FilterOptions
        • pyarrow.compute.IndexOptions
        • pyarrow.compute.JoinOptions
        • pyarrow.compute.ListSliceOptions
        • pyarrow.compute.MakeStructOptions
        • pyarrow.compute.MapLookupOptions
        • pyarrow.compute.MatchSubstringOptions
        • pyarrow.compute.ModeOptions
        • pyarrow.compute.NullOptions
        • pyarrow.compute.PadOptions
        • pyarrow.compute.ZeroFillOptions
        • pyarrow.compute.PairwiseOptions
        • pyarrow.compute.PartitionNthOptions
        • pyarrow.compute.PivotWiderOptions
        • pyarrow.compute.QuantileOptions
        • pyarrow.compute.ReplaceSliceOptions
        • pyarrow.compute.ReplaceSubstringOptions
        • pyarrow.compute.RoundOptions
        • pyarrow.compute.RoundTemporalOptions
        • pyarrow.compute.RoundToMultipleOptions
        • pyarrow.compute.RunEndEncodeOptions
        • pyarrow.compute.ScalarAggregateOptions
        • pyarrow.compute.SelectKOptions
        • pyarrow.compute.SetLookupOptions
        • pyarrow.compute.SliceOptions
        • pyarrow.compute.SortOptions
        • pyarrow.compute.SplitOptions
        • pyarrow.compute.SplitPatternOptions
        • pyarrow.compute.StrftimeOptions
        • pyarrow.compute.StrptimeOptions
        • pyarrow.compute.StructFieldOptions
        • pyarrow.compute.TakeOptions
        • pyarrow.compute.TDigestOptions
        • pyarrow.compute.TrimOptions
        • pyarrow.compute.VarianceOptions
        • pyarrow.compute.WeekOptions
        • pyarrow.compute.register_scalar_function
        • pyarrow.compute.UdfContext
        • pyarrow.compute.field
        • pyarrow.compute.scalar
      • Acero - Streaming Execution Engine
        • pyarrow.acero.Declaration
        • pyarrow.acero.ExecNodeOptions
        • pyarrow.acero.TableSourceNodeOptions
        • pyarrow.acero.ScanNodeOptions
        • pyarrow.acero.FilterNodeOptions
        • pyarrow.acero.ProjectNodeOptions
        • pyarrow.acero.AggregateNodeOptions
        • pyarrow.acero.OrderByNodeOptions
        • pyarrow.acero.HashJoinNodeOptions
      • Substrait
        • pyarrow.substrait.run_query
        • pyarrow.substrait.BoundExpressions
        • pyarrow.substrait.deserialize_expressions
        • pyarrow.substrait.serialize_expressions
        • pyarrow.substrait.serialize_schema
        • pyarrow.substrait.deserialize_schema
        • pyarrow.substrait.SubstraitSchema
        • pyarrow.substrait.get_supported_functions
      • Streams and File Access
        • pyarrow.input_stream
        • pyarrow.output_stream
        • pyarrow.memory_map
        • pyarrow.create_memory_map
        • pyarrow.NativeFile
        • pyarrow.OSFile
        • pyarrow.PythonFile
        • pyarrow.BufferReader
        • pyarrow.BufferOutputStream
        • pyarrow.FixedSizeBufferWriter
        • pyarrow.MemoryMappedFile
        • pyarrow.CompressedInputStream
        • pyarrow.CompressedOutputStream
      • Serialization and IPC
        • pyarrow.ipc.new_file
        • pyarrow.ipc.open_file
        • pyarrow.ipc.new_stream
        • pyarrow.ipc.open_stream
        • pyarrow.ipc.read_message
        • pyarrow.ipc.read_record_batch
        • pyarrow.ipc.get_record_batch_size
        • pyarrow.ipc.read_tensor
        • pyarrow.ipc.write_tensor
        • pyarrow.ipc.get_tensor_size
        • pyarrow.ipc.IpcReadOptions
        • pyarrow.ipc.IpcWriteOptions
        • pyarrow.ipc.Message
        • pyarrow.ipc.MessageReader
        • pyarrow.ipc.RecordBatchFileReader
        • pyarrow.ipc.RecordBatchFileWriter
        • pyarrow.ipc.RecordBatchStreamReader
        • pyarrow.ipc.RecordBatchStreamWriter
      • Arrow Flight
        • pyarrow.flight.Action
        • pyarrow.flight.ActionType
        • pyarrow.flight.DescriptorType
        • pyarrow.flight.FlightDescriptor
        • pyarrow.flight.FlightEndpoint
        • pyarrow.flight.FlightInfo
        • pyarrow.flight.Location
        • pyarrow.flight.MetadataRecordBatchReader
        • pyarrow.flight.MetadataRecordBatchWriter
        • pyarrow.flight.Ticket
        • pyarrow.flight.Result
        • pyarrow.flight.connect
        • pyarrow.flight.FlightCallOptions
        • pyarrow.flight.FlightClient
        • pyarrow.flight.FlightStreamReader
        • pyarrow.flight.FlightStreamWriter
        • pyarrow.flight.ClientMiddlewareFactory
        • pyarrow.flight.ClientMiddleware
        • pyarrow.flight.FlightDataStream
        • pyarrow.flight.FlightMetadataWriter
        • pyarrow.flight.FlightServerBase
        • pyarrow.flight.GeneratorStream
        • pyarrow.flight.RecordBatchStream
        • pyarrow.flight.ServerCallContext
        • pyarrow.flight.ServerMiddlewareFactory
        • pyarrow.flight.ServerMiddleware
        • pyarrow.flight.ClientAuthHandler
        • pyarrow.flight.ServerAuthHandler
        • pyarrow.flight.FlightError
        • pyarrow.flight.FlightCancelledError
        • pyarrow.flight.FlightInternalError
        • pyarrow.flight.FlightServerError
        • pyarrow.flight.FlightTimedOutError
        • pyarrow.flight.FlightUnauthenticatedError
        • pyarrow.flight.FlightUnauthorizedError
        • pyarrow.flight.FlightUnavailableError
        • pyarrow.flight.FlightWriteSizeExceededError
        • pyarrow.flight.FlightMethod
        • pyarrow.flight.CallInfo
      • Tabular File Formats
        • pyarrow.csv.ConvertOptions
        • pyarrow.csv.CSVStreamingReader
        • pyarrow.csv.CSVWriter
        • pyarrow.csv.ISO8601
        • pyarrow.csv.ParseOptions
        • pyarrow.csv.ReadOptions
        • pyarrow.csv.WriteOptions
        • pyarrow.csv.open_csv
        • pyarrow.csv.read_csv
        • pyarrow.csv.write_csv
        • pyarrow.csv.InvalidRow
        • pyarrow.feather.read_feather
        • pyarrow.feather.read_table
        • pyarrow.feather.write_feather
        • pyarrow.json.ReadOptions
        • pyarrow.json.ParseOptions
        • pyarrow.json.open_json
        • pyarrow.json.read_json
        • pyarrow.parquet.ParquetDataset
        • pyarrow.parquet.ParquetFile
        • pyarrow.parquet.ParquetWriter
        • pyarrow.parquet.read_table
        • pyarrow.parquet.read_metadata
        • pyarrow.parquet.read_pandas
        • pyarrow.parquet.read_schema
        • pyarrow.parquet.write_metadata
        • pyarrow.parquet.write_table
        • pyarrow.parquet.write_to_dataset
        • pyarrow.parquet.FileMetaData
        • pyarrow.parquet.RowGroupMetaData
        • pyarrow.parquet.SortingColumn
        • pyarrow.parquet.ColumnChunkMetaData
        • pyarrow.parquet.Statistics
        • pyarrow.parquet.ParquetSchema
        • pyarrow.parquet.ColumnSchema
        • pyarrow.parquet.ParquetLogicalType
        • pyarrow.parquet.encryption.CryptoFactory
        • pyarrow.parquet.encryption.KmsClient
        • pyarrow.parquet.encryption.KmsConnectionConfig
        • pyarrow.parquet.encryption.EncryptionConfiguration
        • pyarrow.parquet.encryption.DecryptionConfiguration
        • pyarrow.orc.ORCFile
        • pyarrow.orc.ORCWriter
        • pyarrow.orc.read_table
        • pyarrow.orc.write_table
      • Filesystems
        • pyarrow.fs.FileInfo
        • pyarrow.fs.FileSelector
        • pyarrow.fs.FileSystem
        • pyarrow.fs.LocalFileSystem
        • pyarrow.fs.S3FileSystem
        • pyarrow.fs.GcsFileSystem
        • pyarrow.fs.HadoopFileSystem
        • pyarrow.fs.SubTreeFileSystem
        • pyarrow.fs.AzureFileSystem
        • pyarrow.fs.PyFileSystem
        • pyarrow.fs.FileSystemHandler
        • pyarrow.fs.FSSpecHandler
        • pyarrow.fs.copy_files
        • pyarrow.fs.initialize_s3
        • pyarrow.fs.finalize_s3
        • pyarrow.fs.resolve_s3_region
        • pyarrow.fs.S3LogLevel
      • Dataset
        • pyarrow.dataset.dataset
        • pyarrow.dataset.parquet_dataset
        • pyarrow.dataset.partitioning
        • pyarrow.dataset.field
        • pyarrow.dataset.scalar
        • pyarrow.dataset.write_dataset
        • pyarrow.dataset.FileFormat
        • pyarrow.dataset.CsvFileFormat
        • pyarrow.dataset.CsvFragmentScanOptions
        • pyarrow.dataset.IpcFileFormat
        • pyarrow.dataset.JsonFileFormat
        • pyarrow.dataset.ParquetFileFormat
        • pyarrow.dataset.ParquetReadOptions
        • pyarrow.dataset.ParquetFragmentScanOptions
        • pyarrow.dataset.ParquetFileFragment
        • pyarrow.dataset.OrcFileFormat
        • pyarrow.dataset.Partitioning
        • pyarrow.dataset.PartitioningFactory
        • pyarrow.dataset.DirectoryPartitioning
        • pyarrow.dataset.HivePartitioning
        • pyarrow.dataset.FilenamePartitioning
        • pyarrow.dataset.Dataset
        • pyarrow.dataset.FileSystemDataset
        • pyarrow.dataset.FileSystemFactoryOptions
        • pyarrow.dataset.FileSystemDatasetFactory
        • pyarrow.dataset.UnionDataset
        • pyarrow.dataset.Fragment
        • pyarrow.dataset.FragmentScanOptions
        • pyarrow.dataset.TaggedRecordBatch
        • pyarrow.dataset.Scanner
        • pyarrow.dataset.Expression
        • pyarrow.dataset.InMemoryDataset
        • pyarrow.dataset.WrittenFile
        • pyarrow.dataset.get_partition_keys
      • CUDA Integration
        • pyarrow.cuda.Context
        • pyarrow.cuda.CudaBuffer
        • pyarrow.cuda.new_host_buffer
        • pyarrow.cuda.HostBuffer
        • pyarrow.cuda.BufferReader
        • pyarrow.cuda.BufferWriter
        • pyarrow.cuda.serialize_record_batch
        • pyarrow.cuda.read_record_batch
        • pyarrow.cuda.read_message
        • pyarrow.cuda.IpcMemHandle
      • Miscellaneous
        • pyarrow.cpu_count
        • pyarrow.set_cpu_count
        • pyarrow.io_thread_count
        • pyarrow.set_io_thread_count
        • pyarrow.get_include
        • pyarrow.get_libraries
        • pyarrow.get_library_dirs
    • Getting Involved
    • Benchmarks
    • Python cookbook
  • R
  • Ruby
  • Rust
  • Swift
  • nanoarrow
  • Implementation Status
  • Implementations
  • Apache Arrow GLib (C)

Apache Arrow GLib (C)#

Apache Arrow GLib is a wrapper library for Apache Arrow C++. Apache Arrow GLib provides C API.

Apache Arrow GLib supports GObject Introspection. It means that you can create language bindings at runtime or compile time automatically.

API reference manuals#

  • Apache Arrow GLib
  • Apache Arrow CUDA GLib
  • Apache Arrow Dataset
  • Apache Arrow Flight GLib
  • Apache Arrow Flight SQL GLib
  • Apache Parquet GLib
  • Gandiva GLib

previous

Dataset

next

Apache Arrow GLib

On this page
  • API reference manuals
Edit on GitHub

© Copyright 2016-2025 Apache Software Foundation. Apache Arrow, Arrow, Apache, the Apache logo, and the Apache Arrow project logo are either registered trademarks or trademarks of The Apache Software Foundation in the United States and other countries.

Created using Sphinx 8.2.3.

Built with the PyData Sphinx Theme 0.16.1.